GET GetAttachment
{{baseUrl}}/v3/attachments/:attachmentId/views/:viewId
QUERY PARAMS

attachmentId
viewId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/attachments/:attachmentId/views/:viewId");

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

(client/get "{{baseUrl}}/v3/attachments/:attachmentId/views/:viewId")
require "http/client"

url = "{{baseUrl}}/v3/attachments/:attachmentId/views/:viewId"

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

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

func main() {

	url := "{{baseUrl}}/v3/attachments/:attachmentId/views/:viewId"

	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/v3/attachments/:attachmentId/views/:viewId HTTP/1.1
Host: example.com

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v3/attachments/:attachmentId/views/:viewId'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v3/attachments/:attachmentId/views/:viewId")
  .get()
  .build()

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

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

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

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

const req = unirest('GET', '{{baseUrl}}/v3/attachments/:attachmentId/views/:viewId');

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}}/v3/attachments/:attachmentId/views/:viewId'
};

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

const url = '{{baseUrl}}/v3/attachments/:attachmentId/views/:viewId';
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}}/v3/attachments/:attachmentId/views/:viewId"]
                                                       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}}/v3/attachments/:attachmentId/views/:viewId" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/v3/attachments/:attachmentId/views/:viewId');
$request->setMethod(HTTP_METH_GET);

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

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

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

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

conn.request("GET", "/baseUrl/v3/attachments/:attachmentId/views/:viewId")

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

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

url = "{{baseUrl}}/v3/attachments/:attachmentId/views/:viewId"

response = requests.get(url)

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

url <- "{{baseUrl}}/v3/attachments/:attachmentId/views/:viewId"

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

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

url = URI("{{baseUrl}}/v3/attachments/:attachmentId/views/:viewId")

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/v3/attachments/:attachmentId/views/:viewId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/attachments/:attachmentId/views/:viewId";

    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}}/v3/attachments/:attachmentId/views/:viewId
http GET {{baseUrl}}/v3/attachments/:attachmentId/views/:viewId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v3/attachments/:attachmentId/views/:viewId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/attachments/:attachmentId/views/:viewId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

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

dataTask.resume()
GET GetAttachmentInfo
{{baseUrl}}/v3/attachments/:attachmentId
QUERY PARAMS

attachmentId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/attachments/:attachmentId");

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

(client/get "{{baseUrl}}/v3/attachments/:attachmentId")
require "http/client"

url = "{{baseUrl}}/v3/attachments/:attachmentId"

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

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

func main() {

	url := "{{baseUrl}}/v3/attachments/:attachmentId"

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

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/v3/attachments/:attachmentId'};

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

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

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

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

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

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

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

const req = unirest('GET', '{{baseUrl}}/v3/attachments/:attachmentId');

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}}/v3/attachments/:attachmentId'};

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/v3/attachments/:attachmentId")

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

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

url = "{{baseUrl}}/v3/attachments/:attachmentId"

response = requests.get(url)

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

url <- "{{baseUrl}}/v3/attachments/:attachmentId"

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

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

url = URI("{{baseUrl}}/v3/attachments/:attachmentId")

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/v3/attachments/:attachmentId') do |req|
end

puts response.status
puts response.body
use reqwest;

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

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

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

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

dataTask.resume()
POST PostActivity
{{baseUrl}}/v3/connectorInternals/activity
BODY json

{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/activity");

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  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}");

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

(client/post "{{baseUrl}}/v3/connectorInternals/activity" {:content-type :json
                                                                           :form-params {:type ""
                                                                                         :id ""
                                                                                         :timestamp ""
                                                                                         :localTimestamp ""
                                                                                         :localTimezone ""
                                                                                         :callerId ""
                                                                                         :serviceUrl ""
                                                                                         :channelId ""
                                                                                         :from {:id ""
                                                                                                :name ""
                                                                                                :aadObjectId ""
                                                                                                :role ""}
                                                                                         :conversation {:isGroup false
                                                                                                        :conversationType ""
                                                                                                        :tenantId ""
                                                                                                        :id ""
                                                                                                        :name ""
                                                                                                        :aadObjectId ""
                                                                                                        :role ""}
                                                                                         :recipient {}
                                                                                         :textFormat ""
                                                                                         :attachmentLayout ""
                                                                                         :membersAdded [{}]
                                                                                         :membersRemoved [{}]
                                                                                         :reactionsAdded [{:type ""}]
                                                                                         :reactionsRemoved [{}]
                                                                                         :topicName ""
                                                                                         :historyDisclosed false
                                                                                         :locale ""
                                                                                         :text ""
                                                                                         :speak ""
                                                                                         :inputHint ""
                                                                                         :summary ""
                                                                                         :suggestedActions {:to []
                                                                                                            :actions [{:type ""
                                                                                                                       :title ""
                                                                                                                       :image ""
                                                                                                                       :imageAltText ""
                                                                                                                       :text ""
                                                                                                                       :displayText ""
                                                                                                                       :value {}
                                                                                                                       :channelData {}}]}
                                                                                         :attachments [{:contentType ""
                                                                                                        :contentUrl ""
                                                                                                        :content {}
                                                                                                        :name ""
                                                                                                        :thumbnailUrl ""}]
                                                                                         :entities [{:type ""}]
                                                                                         :channelData {}
                                                                                         :action ""
                                                                                         :replyToId ""
                                                                                         :label ""
                                                                                         :valueType ""
                                                                                         :value {}
                                                                                         :name ""
                                                                                         :relatesTo {:activityId ""
                                                                                                     :user {}
                                                                                                     :bot {}
                                                                                                     :conversation {}
                                                                                                     :channelId ""
                                                                                                     :serviceUrl ""
                                                                                                     :locale ""}
                                                                                         :code ""
                                                                                         :expiration ""
                                                                                         :importance ""
                                                                                         :deliveryMode ""
                                                                                         :listenFor []
                                                                                         :textHighlights [{:text ""
                                                                                                           :occurrence 0}]
                                                                                         :semanticAction {:state ""
                                                                                                          :id ""
                                                                                                          :entities {}}}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/activity"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/activity"),
    Content = new StringContent("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3/connectorInternals/activity");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/activity"

	payload := strings.NewReader("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")

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

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

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

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

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

}
POST /baseUrl/v3/connectorInternals/activity HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1745

{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/activity")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/activity"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/activity")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/activity")
  .header("content-type", "application/json")
  .body("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")
  .asString();
const data = JSON.stringify({
  type: '',
  id: '',
  timestamp: '',
  localTimestamp: '',
  localTimezone: '',
  callerId: '',
  serviceUrl: '',
  channelId: '',
  from: {
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  conversation: {
    isGroup: false,
    conversationType: '',
    tenantId: '',
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  recipient: {},
  textFormat: '',
  attachmentLayout: '',
  membersAdded: [
    {}
  ],
  membersRemoved: [
    {}
  ],
  reactionsAdded: [
    {
      type: ''
    }
  ],
  reactionsRemoved: [
    {}
  ],
  topicName: '',
  historyDisclosed: false,
  locale: '',
  text: '',
  speak: '',
  inputHint: '',
  summary: '',
  suggestedActions: {
    to: [],
    actions: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ]
  },
  attachments: [
    {
      contentType: '',
      contentUrl: '',
      content: {},
      name: '',
      thumbnailUrl: ''
    }
  ],
  entities: [
    {
      type: ''
    }
  ],
  channelData: {},
  action: '',
  replyToId: '',
  label: '',
  valueType: '',
  value: {},
  name: '',
  relatesTo: {
    activityId: '',
    user: {},
    bot: {},
    conversation: {},
    channelId: '',
    serviceUrl: '',
    locale: ''
  },
  code: '',
  expiration: '',
  importance: '',
  deliveryMode: '',
  listenFor: [],
  textHighlights: [
    {
      text: '',
      occurrence: 0
    }
  ],
  semanticAction: {
    state: '',
    id: '',
    entities: {}
  }
});

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

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

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/activity');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/activity',
  headers: {'content-type': 'application/json'},
  data: {
    type: '',
    id: '',
    timestamp: '',
    localTimestamp: '',
    localTimezone: '',
    callerId: '',
    serviceUrl: '',
    channelId: '',
    from: {id: '', name: '', aadObjectId: '', role: ''},
    conversation: {
      isGroup: false,
      conversationType: '',
      tenantId: '',
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    recipient: {},
    textFormat: '',
    attachmentLayout: '',
    membersAdded: [{}],
    membersRemoved: [{}],
    reactionsAdded: [{type: ''}],
    reactionsRemoved: [{}],
    topicName: '',
    historyDisclosed: false,
    locale: '',
    text: '',
    speak: '',
    inputHint: '',
    summary: '',
    suggestedActions: {
      to: [],
      actions: [
        {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      ]
    },
    attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
    entities: [{type: ''}],
    channelData: {},
    action: '',
    replyToId: '',
    label: '',
    valueType: '',
    value: {},
    name: '',
    relatesTo: {
      activityId: '',
      user: {},
      bot: {},
      conversation: {},
      channelId: '',
      serviceUrl: '',
      locale: ''
    },
    code: '',
    expiration: '',
    importance: '',
    deliveryMode: '',
    listenFor: [],
    textHighlights: [{text: '', occurrence: 0}],
    semanticAction: {state: '', id: '', entities: {}}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/activity';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"type":"","id":"","timestamp":"","localTimestamp":"","localTimezone":"","callerId":"","serviceUrl":"","channelId":"","from":{"id":"","name":"","aadObjectId":"","role":""},"conversation":{"isGroup":false,"conversationType":"","tenantId":"","id":"","name":"","aadObjectId":"","role":""},"recipient":{},"textFormat":"","attachmentLayout":"","membersAdded":[{}],"membersRemoved":[{}],"reactionsAdded":[{"type":""}],"reactionsRemoved":[{}],"topicName":"","historyDisclosed":false,"locale":"","text":"","speak":"","inputHint":"","summary":"","suggestedActions":{"to":[],"actions":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}]},"attachments":[{"contentType":"","contentUrl":"","content":{},"name":"","thumbnailUrl":""}],"entities":[{"type":""}],"channelData":{},"action":"","replyToId":"","label":"","valueType":"","value":{},"name":"","relatesTo":{"activityId":"","user":{},"bot":{},"conversation":{},"channelId":"","serviceUrl":"","locale":""},"code":"","expiration":"","importance":"","deliveryMode":"","listenFor":[],"textHighlights":[{"text":"","occurrence":0}],"semanticAction":{"state":"","id":"","entities":{}}}'
};

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}}/v3/connectorInternals/activity',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "type": "",\n  "id": "",\n  "timestamp": "",\n  "localTimestamp": "",\n  "localTimezone": "",\n  "callerId": "",\n  "serviceUrl": "",\n  "channelId": "",\n  "from": {\n    "id": "",\n    "name": "",\n    "aadObjectId": "",\n    "role": ""\n  },\n  "conversation": {\n    "isGroup": false,\n    "conversationType": "",\n    "tenantId": "",\n    "id": "",\n    "name": "",\n    "aadObjectId": "",\n    "role": ""\n  },\n  "recipient": {},\n  "textFormat": "",\n  "attachmentLayout": "",\n  "membersAdded": [\n    {}\n  ],\n  "membersRemoved": [\n    {}\n  ],\n  "reactionsAdded": [\n    {\n      "type": ""\n    }\n  ],\n  "reactionsRemoved": [\n    {}\n  ],\n  "topicName": "",\n  "historyDisclosed": false,\n  "locale": "",\n  "text": "",\n  "speak": "",\n  "inputHint": "",\n  "summary": "",\n  "suggestedActions": {\n    "to": [],\n    "actions": [\n      {\n        "type": "",\n        "title": "",\n        "image": "",\n        "imageAltText": "",\n        "text": "",\n        "displayText": "",\n        "value": {},\n        "channelData": {}\n      }\n    ]\n  },\n  "attachments": [\n    {\n      "contentType": "",\n      "contentUrl": "",\n      "content": {},\n      "name": "",\n      "thumbnailUrl": ""\n    }\n  ],\n  "entities": [\n    {\n      "type": ""\n    }\n  ],\n  "channelData": {},\n  "action": "",\n  "replyToId": "",\n  "label": "",\n  "valueType": "",\n  "value": {},\n  "name": "",\n  "relatesTo": {\n    "activityId": "",\n    "user": {},\n    "bot": {},\n    "conversation": {},\n    "channelId": "",\n    "serviceUrl": "",\n    "locale": ""\n  },\n  "code": "",\n  "expiration": "",\n  "importance": "",\n  "deliveryMode": "",\n  "listenFor": [],\n  "textHighlights": [\n    {\n      "text": "",\n      "occurrence": 0\n    }\n  ],\n  "semanticAction": {\n    "state": "",\n    "id": "",\n    "entities": {}\n  }\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/activity")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/activity',
  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({
  type: '',
  id: '',
  timestamp: '',
  localTimestamp: '',
  localTimezone: '',
  callerId: '',
  serviceUrl: '',
  channelId: '',
  from: {id: '', name: '', aadObjectId: '', role: ''},
  conversation: {
    isGroup: false,
    conversationType: '',
    tenantId: '',
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  recipient: {},
  textFormat: '',
  attachmentLayout: '',
  membersAdded: [{}],
  membersRemoved: [{}],
  reactionsAdded: [{type: ''}],
  reactionsRemoved: [{}],
  topicName: '',
  historyDisclosed: false,
  locale: '',
  text: '',
  speak: '',
  inputHint: '',
  summary: '',
  suggestedActions: {
    to: [],
    actions: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ]
  },
  attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
  entities: [{type: ''}],
  channelData: {},
  action: '',
  replyToId: '',
  label: '',
  valueType: '',
  value: {},
  name: '',
  relatesTo: {
    activityId: '',
    user: {},
    bot: {},
    conversation: {},
    channelId: '',
    serviceUrl: '',
    locale: ''
  },
  code: '',
  expiration: '',
  importance: '',
  deliveryMode: '',
  listenFor: [],
  textHighlights: [{text: '', occurrence: 0}],
  semanticAction: {state: '', id: '', entities: {}}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/activity',
  headers: {'content-type': 'application/json'},
  body: {
    type: '',
    id: '',
    timestamp: '',
    localTimestamp: '',
    localTimezone: '',
    callerId: '',
    serviceUrl: '',
    channelId: '',
    from: {id: '', name: '', aadObjectId: '', role: ''},
    conversation: {
      isGroup: false,
      conversationType: '',
      tenantId: '',
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    recipient: {},
    textFormat: '',
    attachmentLayout: '',
    membersAdded: [{}],
    membersRemoved: [{}],
    reactionsAdded: [{type: ''}],
    reactionsRemoved: [{}],
    topicName: '',
    historyDisclosed: false,
    locale: '',
    text: '',
    speak: '',
    inputHint: '',
    summary: '',
    suggestedActions: {
      to: [],
      actions: [
        {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      ]
    },
    attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
    entities: [{type: ''}],
    channelData: {},
    action: '',
    replyToId: '',
    label: '',
    valueType: '',
    value: {},
    name: '',
    relatesTo: {
      activityId: '',
      user: {},
      bot: {},
      conversation: {},
      channelId: '',
      serviceUrl: '',
      locale: ''
    },
    code: '',
    expiration: '',
    importance: '',
    deliveryMode: '',
    listenFor: [],
    textHighlights: [{text: '', occurrence: 0}],
    semanticAction: {state: '', id: '', entities: {}}
  },
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/activity');

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

req.type('json');
req.send({
  type: '',
  id: '',
  timestamp: '',
  localTimestamp: '',
  localTimezone: '',
  callerId: '',
  serviceUrl: '',
  channelId: '',
  from: {
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  conversation: {
    isGroup: false,
    conversationType: '',
    tenantId: '',
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  recipient: {},
  textFormat: '',
  attachmentLayout: '',
  membersAdded: [
    {}
  ],
  membersRemoved: [
    {}
  ],
  reactionsAdded: [
    {
      type: ''
    }
  ],
  reactionsRemoved: [
    {}
  ],
  topicName: '',
  historyDisclosed: false,
  locale: '',
  text: '',
  speak: '',
  inputHint: '',
  summary: '',
  suggestedActions: {
    to: [],
    actions: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ]
  },
  attachments: [
    {
      contentType: '',
      contentUrl: '',
      content: {},
      name: '',
      thumbnailUrl: ''
    }
  ],
  entities: [
    {
      type: ''
    }
  ],
  channelData: {},
  action: '',
  replyToId: '',
  label: '',
  valueType: '',
  value: {},
  name: '',
  relatesTo: {
    activityId: '',
    user: {},
    bot: {},
    conversation: {},
    channelId: '',
    serviceUrl: '',
    locale: ''
  },
  code: '',
  expiration: '',
  importance: '',
  deliveryMode: '',
  listenFor: [],
  textHighlights: [
    {
      text: '',
      occurrence: 0
    }
  ],
  semanticAction: {
    state: '',
    id: '',
    entities: {}
  }
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/activity',
  headers: {'content-type': 'application/json'},
  data: {
    type: '',
    id: '',
    timestamp: '',
    localTimestamp: '',
    localTimezone: '',
    callerId: '',
    serviceUrl: '',
    channelId: '',
    from: {id: '', name: '', aadObjectId: '', role: ''},
    conversation: {
      isGroup: false,
      conversationType: '',
      tenantId: '',
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    recipient: {},
    textFormat: '',
    attachmentLayout: '',
    membersAdded: [{}],
    membersRemoved: [{}],
    reactionsAdded: [{type: ''}],
    reactionsRemoved: [{}],
    topicName: '',
    historyDisclosed: false,
    locale: '',
    text: '',
    speak: '',
    inputHint: '',
    summary: '',
    suggestedActions: {
      to: [],
      actions: [
        {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      ]
    },
    attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
    entities: [{type: ''}],
    channelData: {},
    action: '',
    replyToId: '',
    label: '',
    valueType: '',
    value: {},
    name: '',
    relatesTo: {
      activityId: '',
      user: {},
      bot: {},
      conversation: {},
      channelId: '',
      serviceUrl: '',
      locale: ''
    },
    code: '',
    expiration: '',
    importance: '',
    deliveryMode: '',
    listenFor: [],
    textHighlights: [{text: '', occurrence: 0}],
    semanticAction: {state: '', id: '', entities: {}}
  }
};

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

const url = '{{baseUrl}}/v3/connectorInternals/activity';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"type":"","id":"","timestamp":"","localTimestamp":"","localTimezone":"","callerId":"","serviceUrl":"","channelId":"","from":{"id":"","name":"","aadObjectId":"","role":""},"conversation":{"isGroup":false,"conversationType":"","tenantId":"","id":"","name":"","aadObjectId":"","role":""},"recipient":{},"textFormat":"","attachmentLayout":"","membersAdded":[{}],"membersRemoved":[{}],"reactionsAdded":[{"type":""}],"reactionsRemoved":[{}],"topicName":"","historyDisclosed":false,"locale":"","text":"","speak":"","inputHint":"","summary":"","suggestedActions":{"to":[],"actions":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}]},"attachments":[{"contentType":"","contentUrl":"","content":{},"name":"","thumbnailUrl":""}],"entities":[{"type":""}],"channelData":{},"action":"","replyToId":"","label":"","valueType":"","value":{},"name":"","relatesTo":{"activityId":"","user":{},"bot":{},"conversation":{},"channelId":"","serviceUrl":"","locale":""},"code":"","expiration":"","importance":"","deliveryMode":"","listenFor":[],"textHighlights":[{"text":"","occurrence":0}],"semanticAction":{"state":"","id":"","entities":{}}}'
};

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 = @{ @"type": @"",
                              @"id": @"",
                              @"timestamp": @"",
                              @"localTimestamp": @"",
                              @"localTimezone": @"",
                              @"callerId": @"",
                              @"serviceUrl": @"",
                              @"channelId": @"",
                              @"from": @{ @"id": @"", @"name": @"", @"aadObjectId": @"", @"role": @"" },
                              @"conversation": @{ @"isGroup": @NO, @"conversationType": @"", @"tenantId": @"", @"id": @"", @"name": @"", @"aadObjectId": @"", @"role": @"" },
                              @"recipient": @{  },
                              @"textFormat": @"",
                              @"attachmentLayout": @"",
                              @"membersAdded": @[ @{  } ],
                              @"membersRemoved": @[ @{  } ],
                              @"reactionsAdded": @[ @{ @"type": @"" } ],
                              @"reactionsRemoved": @[ @{  } ],
                              @"topicName": @"",
                              @"historyDisclosed": @NO,
                              @"locale": @"",
                              @"text": @"",
                              @"speak": @"",
                              @"inputHint": @"",
                              @"summary": @"",
                              @"suggestedActions": @{ @"to": @[  ], @"actions": @[ @{ @"type": @"", @"title": @"", @"image": @"", @"imageAltText": @"", @"text": @"", @"displayText": @"", @"value": @{  }, @"channelData": @{  } } ] },
                              @"attachments": @[ @{ @"contentType": @"", @"contentUrl": @"", @"content": @{  }, @"name": @"", @"thumbnailUrl": @"" } ],
                              @"entities": @[ @{ @"type": @"" } ],
                              @"channelData": @{  },
                              @"action": @"",
                              @"replyToId": @"",
                              @"label": @"",
                              @"valueType": @"",
                              @"value": @{  },
                              @"name": @"",
                              @"relatesTo": @{ @"activityId": @"", @"user": @{  }, @"bot": @{  }, @"conversation": @{  }, @"channelId": @"", @"serviceUrl": @"", @"locale": @"" },
                              @"code": @"",
                              @"expiration": @"",
                              @"importance": @"",
                              @"deliveryMode": @"",
                              @"listenFor": @[  ],
                              @"textHighlights": @[ @{ @"text": @"", @"occurrence": @0 } ],
                              @"semanticAction": @{ @"state": @"", @"id": @"", @"entities": @{  } } };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/activity" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/activity",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'type' => '',
    'id' => '',
    'timestamp' => '',
    'localTimestamp' => '',
    'localTimezone' => '',
    'callerId' => '',
    'serviceUrl' => '',
    'channelId' => '',
    'from' => [
        'id' => '',
        'name' => '',
        'aadObjectId' => '',
        'role' => ''
    ],
    'conversation' => [
        'isGroup' => null,
        'conversationType' => '',
        'tenantId' => '',
        'id' => '',
        'name' => '',
        'aadObjectId' => '',
        'role' => ''
    ],
    'recipient' => [
        
    ],
    'textFormat' => '',
    'attachmentLayout' => '',
    'membersAdded' => [
        [
                
        ]
    ],
    'membersRemoved' => [
        [
                
        ]
    ],
    'reactionsAdded' => [
        [
                'type' => ''
        ]
    ],
    'reactionsRemoved' => [
        [
                
        ]
    ],
    'topicName' => '',
    'historyDisclosed' => null,
    'locale' => '',
    'text' => '',
    'speak' => '',
    'inputHint' => '',
    'summary' => '',
    'suggestedActions' => [
        'to' => [
                
        ],
        'actions' => [
                [
                                'type' => '',
                                'title' => '',
                                'image' => '',
                                'imageAltText' => '',
                                'text' => '',
                                'displayText' => '',
                                'value' => [
                                                                
                                ],
                                'channelData' => [
                                                                
                                ]
                ]
        ]
    ],
    'attachments' => [
        [
                'contentType' => '',
                'contentUrl' => '',
                'content' => [
                                
                ],
                'name' => '',
                'thumbnailUrl' => ''
        ]
    ],
    'entities' => [
        [
                'type' => ''
        ]
    ],
    'channelData' => [
        
    ],
    'action' => '',
    'replyToId' => '',
    'label' => '',
    'valueType' => '',
    'value' => [
        
    ],
    'name' => '',
    'relatesTo' => [
        'activityId' => '',
        'user' => [
                
        ],
        'bot' => [
                
        ],
        'conversation' => [
                
        ],
        'channelId' => '',
        'serviceUrl' => '',
        'locale' => ''
    ],
    'code' => '',
    'expiration' => '',
    'importance' => '',
    'deliveryMode' => '',
    'listenFor' => [
        
    ],
    'textHighlights' => [
        [
                'text' => '',
                'occurrence' => 0
        ]
    ],
    'semanticAction' => [
        'state' => '',
        'id' => '',
        'entities' => [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/activity', [
  'body' => '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/activity');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'type' => '',
  'id' => '',
  'timestamp' => '',
  'localTimestamp' => '',
  'localTimezone' => '',
  'callerId' => '',
  'serviceUrl' => '',
  'channelId' => '',
  'from' => [
    'id' => '',
    'name' => '',
    'aadObjectId' => '',
    'role' => ''
  ],
  'conversation' => [
    'isGroup' => null,
    'conversationType' => '',
    'tenantId' => '',
    'id' => '',
    'name' => '',
    'aadObjectId' => '',
    'role' => ''
  ],
  'recipient' => [
    
  ],
  'textFormat' => '',
  'attachmentLayout' => '',
  'membersAdded' => [
    [
        
    ]
  ],
  'membersRemoved' => [
    [
        
    ]
  ],
  'reactionsAdded' => [
    [
        'type' => ''
    ]
  ],
  'reactionsRemoved' => [
    [
        
    ]
  ],
  'topicName' => '',
  'historyDisclosed' => null,
  'locale' => '',
  'text' => '',
  'speak' => '',
  'inputHint' => '',
  'summary' => '',
  'suggestedActions' => [
    'to' => [
        
    ],
    'actions' => [
        [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ]
  ],
  'attachments' => [
    [
        'contentType' => '',
        'contentUrl' => '',
        'content' => [
                
        ],
        'name' => '',
        'thumbnailUrl' => ''
    ]
  ],
  'entities' => [
    [
        'type' => ''
    ]
  ],
  'channelData' => [
    
  ],
  'action' => '',
  'replyToId' => '',
  'label' => '',
  'valueType' => '',
  'value' => [
    
  ],
  'name' => '',
  'relatesTo' => [
    'activityId' => '',
    'user' => [
        
    ],
    'bot' => [
        
    ],
    'conversation' => [
        
    ],
    'channelId' => '',
    'serviceUrl' => '',
    'locale' => ''
  ],
  'code' => '',
  'expiration' => '',
  'importance' => '',
  'deliveryMode' => '',
  'listenFor' => [
    
  ],
  'textHighlights' => [
    [
        'text' => '',
        'occurrence' => 0
    ]
  ],
  'semanticAction' => [
    'state' => '',
    'id' => '',
    'entities' => [
        
    ]
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'type' => '',
  'id' => '',
  'timestamp' => '',
  'localTimestamp' => '',
  'localTimezone' => '',
  'callerId' => '',
  'serviceUrl' => '',
  'channelId' => '',
  'from' => [
    'id' => '',
    'name' => '',
    'aadObjectId' => '',
    'role' => ''
  ],
  'conversation' => [
    'isGroup' => null,
    'conversationType' => '',
    'tenantId' => '',
    'id' => '',
    'name' => '',
    'aadObjectId' => '',
    'role' => ''
  ],
  'recipient' => [
    
  ],
  'textFormat' => '',
  'attachmentLayout' => '',
  'membersAdded' => [
    [
        
    ]
  ],
  'membersRemoved' => [
    [
        
    ]
  ],
  'reactionsAdded' => [
    [
        'type' => ''
    ]
  ],
  'reactionsRemoved' => [
    [
        
    ]
  ],
  'topicName' => '',
  'historyDisclosed' => null,
  'locale' => '',
  'text' => '',
  'speak' => '',
  'inputHint' => '',
  'summary' => '',
  'suggestedActions' => [
    'to' => [
        
    ],
    'actions' => [
        [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ]
  ],
  'attachments' => [
    [
        'contentType' => '',
        'contentUrl' => '',
        'content' => [
                
        ],
        'name' => '',
        'thumbnailUrl' => ''
    ]
  ],
  'entities' => [
    [
        'type' => ''
    ]
  ],
  'channelData' => [
    
  ],
  'action' => '',
  'replyToId' => '',
  'label' => '',
  'valueType' => '',
  'value' => [
    
  ],
  'name' => '',
  'relatesTo' => [
    'activityId' => '',
    'user' => [
        
    ],
    'bot' => [
        
    ],
    'conversation' => [
        
    ],
    'channelId' => '',
    'serviceUrl' => '',
    'locale' => ''
  ],
  'code' => '',
  'expiration' => '',
  'importance' => '',
  'deliveryMode' => '',
  'listenFor' => [
    
  ],
  'textHighlights' => [
    [
        'text' => '',
        'occurrence' => 0
    ]
  ],
  'semanticAction' => [
    'state' => '',
    'id' => '',
    'entities' => [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/activity');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/activity' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/activity' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}'
import http.client

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

payload = "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"

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

conn.request("POST", "/baseUrl/v3/connectorInternals/activity", payload, headers)

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

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

url = "{{baseUrl}}/v3/connectorInternals/activity"

payload = {
    "type": "",
    "id": "",
    "timestamp": "",
    "localTimestamp": "",
    "localTimezone": "",
    "callerId": "",
    "serviceUrl": "",
    "channelId": "",
    "from": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
    },
    "conversation": {
        "isGroup": False,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
    },
    "recipient": {},
    "textFormat": "",
    "attachmentLayout": "",
    "membersAdded": [{}],
    "membersRemoved": [{}],
    "reactionsAdded": [{ "type": "" }],
    "reactionsRemoved": [{}],
    "topicName": "",
    "historyDisclosed": False,
    "locale": "",
    "text": "",
    "speak": "",
    "inputHint": "",
    "summary": "",
    "suggestedActions": {
        "to": [],
        "actions": [
            {
                "type": "",
                "title": "",
                "image": "",
                "imageAltText": "",
                "text": "",
                "displayText": "",
                "value": {},
                "channelData": {}
            }
        ]
    },
    "attachments": [
        {
            "contentType": "",
            "contentUrl": "",
            "content": {},
            "name": "",
            "thumbnailUrl": ""
        }
    ],
    "entities": [{ "type": "" }],
    "channelData": {},
    "action": "",
    "replyToId": "",
    "label": "",
    "valueType": "",
    "value": {},
    "name": "",
    "relatesTo": {
        "activityId": "",
        "user": {},
        "bot": {},
        "conversation": {},
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
    },
    "code": "",
    "expiration": "",
    "importance": "",
    "deliveryMode": "",
    "listenFor": [],
    "textHighlights": [
        {
            "text": "",
            "occurrence": 0
        }
    ],
    "semanticAction": {
        "state": "",
        "id": "",
        "entities": {}
    }
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3/connectorInternals/activity"

payload <- "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v3/connectorInternals/activity")

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

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"

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

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

response = conn.post('/baseUrl/v3/connectorInternals/activity') do |req|
  req.body = "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"
end

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

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

    let payload = json!({
        "type": "",
        "id": "",
        "timestamp": "",
        "localTimestamp": "",
        "localTimezone": "",
        "callerId": "",
        "serviceUrl": "",
        "channelId": "",
        "from": json!({
            "id": "",
            "name": "",
            "aadObjectId": "",
            "role": ""
        }),
        "conversation": json!({
            "isGroup": false,
            "conversationType": "",
            "tenantId": "",
            "id": "",
            "name": "",
            "aadObjectId": "",
            "role": ""
        }),
        "recipient": json!({}),
        "textFormat": "",
        "attachmentLayout": "",
        "membersAdded": (json!({})),
        "membersRemoved": (json!({})),
        "reactionsAdded": (json!({"type": ""})),
        "reactionsRemoved": (json!({})),
        "topicName": "",
        "historyDisclosed": false,
        "locale": "",
        "text": "",
        "speak": "",
        "inputHint": "",
        "summary": "",
        "suggestedActions": json!({
            "to": (),
            "actions": (
                json!({
                    "type": "",
                    "title": "",
                    "image": "",
                    "imageAltText": "",
                    "text": "",
                    "displayText": "",
                    "value": json!({}),
                    "channelData": json!({})
                })
            )
        }),
        "attachments": (
            json!({
                "contentType": "",
                "contentUrl": "",
                "content": json!({}),
                "name": "",
                "thumbnailUrl": ""
            })
        ),
        "entities": (json!({"type": ""})),
        "channelData": json!({}),
        "action": "",
        "replyToId": "",
        "label": "",
        "valueType": "",
        "value": json!({}),
        "name": "",
        "relatesTo": json!({
            "activityId": "",
            "user": json!({}),
            "bot": json!({}),
            "conversation": json!({}),
            "channelId": "",
            "serviceUrl": "",
            "locale": ""
        }),
        "code": "",
        "expiration": "",
        "importance": "",
        "deliveryMode": "",
        "listenFor": (),
        "textHighlights": (
            json!({
                "text": "",
                "occurrence": 0
            })
        ),
        "semanticAction": json!({
            "state": "",
            "id": "",
            "entities": json!({})
        })
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/activity \
  --header 'content-type: application/json' \
  --data '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}'
echo '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/activity \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "type": "",\n  "id": "",\n  "timestamp": "",\n  "localTimestamp": "",\n  "localTimezone": "",\n  "callerId": "",\n  "serviceUrl": "",\n  "channelId": "",\n  "from": {\n    "id": "",\n    "name": "",\n    "aadObjectId": "",\n    "role": ""\n  },\n  "conversation": {\n    "isGroup": false,\n    "conversationType": "",\n    "tenantId": "",\n    "id": "",\n    "name": "",\n    "aadObjectId": "",\n    "role": ""\n  },\n  "recipient": {},\n  "textFormat": "",\n  "attachmentLayout": "",\n  "membersAdded": [\n    {}\n  ],\n  "membersRemoved": [\n    {}\n  ],\n  "reactionsAdded": [\n    {\n      "type": ""\n    }\n  ],\n  "reactionsRemoved": [\n    {}\n  ],\n  "topicName": "",\n  "historyDisclosed": false,\n  "locale": "",\n  "text": "",\n  "speak": "",\n  "inputHint": "",\n  "summary": "",\n  "suggestedActions": {\n    "to": [],\n    "actions": [\n      {\n        "type": "",\n        "title": "",\n        "image": "",\n        "imageAltText": "",\n        "text": "",\n        "displayText": "",\n        "value": {},\n        "channelData": {}\n      }\n    ]\n  },\n  "attachments": [\n    {\n      "contentType": "",\n      "contentUrl": "",\n      "content": {},\n      "name": "",\n      "thumbnailUrl": ""\n    }\n  ],\n  "entities": [\n    {\n      "type": ""\n    }\n  ],\n  "channelData": {},\n  "action": "",\n  "replyToId": "",\n  "label": "",\n  "valueType": "",\n  "value": {},\n  "name": "",\n  "relatesTo": {\n    "activityId": "",\n    "user": {},\n    "bot": {},\n    "conversation": {},\n    "channelId": "",\n    "serviceUrl": "",\n    "locale": ""\n  },\n  "code": "",\n  "expiration": "",\n  "importance": "",\n  "deliveryMode": "",\n  "listenFor": [],\n  "textHighlights": [\n    {\n      "text": "",\n      "occurrence": 0\n    }\n  ],\n  "semanticAction": {\n    "state": "",\n    "id": "",\n    "entities": {}\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/activity
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": [
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  ],
  "conversation": [
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  ],
  "recipient": [],
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [[]],
  "membersRemoved": [[]],
  "reactionsAdded": [["type": ""]],
  "reactionsRemoved": [[]],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": [
    "to": [],
    "actions": [
      [
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": [],
        "channelData": []
      ]
    ]
  ],
  "attachments": [
    [
      "contentType": "",
      "contentUrl": "",
      "content": [],
      "name": "",
      "thumbnailUrl": ""
    ]
  ],
  "entities": [["type": ""]],
  "channelData": [],
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": [],
  "name": "",
  "relatesTo": [
    "activityId": "",
    "user": [],
    "bot": [],
    "conversation": [],
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  ],
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    [
      "text": "",
      "occurrence": 0
    ]
  ],
  "semanticAction": [
    "state": "",
    "id": "",
    "entities": []
  ]
] as [String : Any]

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

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

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

dataTask.resume()
POST PostActivityEventNames
{{baseUrl}}/v3/connectorInternals/activityEventNames
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/activityEventNames");

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

(client/post "{{baseUrl}}/v3/connectorInternals/activityEventNames")
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/activityEventNames"

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

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

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/activityEventNames"

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

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

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

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

}
POST /baseUrl/v3/connectorInternals/activityEventNames HTTP/1.1
Host: example.com

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

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/activityEventNames"))
    .method("POST", 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}}/v3/connectorInternals/activityEventNames")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/activityEventNames")
  .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('POST', '{{baseUrl}}/v3/connectorInternals/activityEventNames');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/activityEventNames'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/activityEventNames';
const options = {method: 'POST'};

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}}/v3/connectorInternals/activityEventNames',
  method: 'POST',
  headers: {}
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/activityEventNames")
  .post(null)
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/activityEventNames',
  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: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/activityEventNames'
};

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

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

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/activityEventNames');

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/activityEventNames'
};

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

const url = '{{baseUrl}}/v3/connectorInternals/activityEventNames';
const options = {method: 'POST'};

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}}/v3/connectorInternals/activityEventNames"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

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}}/v3/connectorInternals/activityEventNames" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/activityEventNames');

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/activityEventNames');
$request->setMethod(HTTP_METH_POST);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v3/connectorInternals/activityEventNames');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/activityEventNames' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/activityEventNames' -Method POST 
import http.client

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

conn.request("POST", "/baseUrl/v3/connectorInternals/activityEventNames")

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

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

url = "{{baseUrl}}/v3/connectorInternals/activityEventNames"

response = requests.post(url)

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

url <- "{{baseUrl}}/v3/connectorInternals/activityEventNames"

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

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

url = URI("{{baseUrl}}/v3/connectorInternals/activityEventNames")

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

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

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

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

response = conn.post('/baseUrl/v3/connectorInternals/activityEventNames') do |req|
end

puts response.status
puts response.body
use reqwest;

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/activityEventNames
http POST {{baseUrl}}/v3/connectorInternals/activityEventNames
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/activityEventNames
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/connectorInternals/activityEventNames")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

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

dataTask.resume()
POST PostAdaptiveCardInvokeAction
{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction
BODY json

{
  "type": "",
  "id": "",
  "verb": "",
  "data": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction");

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  \"type\": \"\",\n  \"id\": \"\",\n  \"verb\": \"\",\n  \"data\": {}\n}");

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

(client/post "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction" {:content-type :json
                                                                                           :form-params {:type ""
                                                                                                         :id ""
                                                                                                         :verb ""
                                                                                                         :data {}}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"verb\": \"\",\n  \"data\": {}\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction"),
    Content = new StringContent("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"verb\": \"\",\n  \"data\": {}\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}}/v3/connectorInternals/adaptiveCardInvokeAction");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"verb\": \"\",\n  \"data\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction"

	payload := strings.NewReader("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"verb\": \"\",\n  \"data\": {}\n}")

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

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

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

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

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

}
POST /baseUrl/v3/connectorInternals/adaptiveCardInvokeAction HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 56

{
  "type": "",
  "id": "",
  "verb": "",
  "data": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"verb\": \"\",\n  \"data\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"verb\": \"\",\n  \"data\": {}\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  \"type\": \"\",\n  \"id\": \"\",\n  \"verb\": \"\",\n  \"data\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction")
  .header("content-type", "application/json")
  .body("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"verb\": \"\",\n  \"data\": {}\n}")
  .asString();
const data = JSON.stringify({
  type: '',
  id: '',
  verb: '',
  data: {}
});

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

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

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction',
  headers: {'content-type': 'application/json'},
  data: {type: '', id: '', verb: '', data: {}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"type":"","id":"","verb":"","data":{}}'
};

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}}/v3/connectorInternals/adaptiveCardInvokeAction',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "type": "",\n  "id": "",\n  "verb": "",\n  "data": {}\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"verb\": \"\",\n  \"data\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/adaptiveCardInvokeAction',
  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({type: '', id: '', verb: '', data: {}}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction',
  headers: {'content-type': 'application/json'},
  body: {type: '', id: '', verb: '', data: {}},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction');

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

req.type('json');
req.send({
  type: '',
  id: '',
  verb: '',
  data: {}
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction',
  headers: {'content-type': 'application/json'},
  data: {type: '', id: '', verb: '', data: {}}
};

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

const url = '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"type":"","id":"","verb":"","data":{}}'
};

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 = @{ @"type": @"",
                              @"id": @"",
                              @"verb": @"",
                              @"data": @{  } };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"verb\": \"\",\n  \"data\": {}\n}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction', [
  'body' => '{
  "type": "",
  "id": "",
  "verb": "",
  "data": {}
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'type' => '',
  'id' => '',
  'verb' => '',
  'data' => [
    
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'type' => '',
  'id' => '',
  'verb' => '',
  'data' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "type": "",
  "id": "",
  "verb": "",
  "data": {}
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "type": "",
  "id": "",
  "verb": "",
  "data": {}
}'
import http.client

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

payload = "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"verb\": \"\",\n  \"data\": {}\n}"

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

conn.request("POST", "/baseUrl/v3/connectorInternals/adaptiveCardInvokeAction", payload, headers)

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

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

url = "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction"

payload = {
    "type": "",
    "id": "",
    "verb": "",
    "data": {}
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction"

payload <- "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"verb\": \"\",\n  \"data\": {}\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction")

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

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

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

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

response = conn.post('/baseUrl/v3/connectorInternals/adaptiveCardInvokeAction') do |req|
  req.body = "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"verb\": \"\",\n  \"data\": {}\n}"
end

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

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

    let payload = json!({
        "type": "",
        "id": "",
        "verb": "",
        "data": json!({})
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction \
  --header 'content-type: application/json' \
  --data '{
  "type": "",
  "id": "",
  "verb": "",
  "data": {}
}'
echo '{
  "type": "",
  "id": "",
  "verb": "",
  "data": {}
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "type": "",\n  "id": "",\n  "verb": "",\n  "data": {}\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeAction
import Foundation

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

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

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

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

dataTask.resume()
POST PostAdaptiveCardInvokeResponse
{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse
BODY json

{
  "statusCode": 0,
  "type": "",
  "value": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse");

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  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}");

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

(client/post "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse" {:content-type :json
                                                                                             :form-params {:statusCode 0
                                                                                                           :type ""
                                                                                                           :value {}}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse"),
    Content = new StringContent("{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\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}}/v3/connectorInternals/adaptiveCardInvokeResponse");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse"

	payload := strings.NewReader("{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}")

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

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

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

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

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

}
POST /baseUrl/v3/connectorInternals/adaptiveCardInvokeResponse HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 50

{
  "statusCode": 0,
  "type": "",
  "value": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\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  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse")
  .header("content-type", "application/json")
  .body("{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}")
  .asString();
const data = JSON.stringify({
  statusCode: 0,
  type: '',
  value: {}
});

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

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

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse',
  headers: {'content-type': 'application/json'},
  data: {statusCode: 0, type: '', value: {}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"statusCode":0,"type":"","value":{}}'
};

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}}/v3/connectorInternals/adaptiveCardInvokeResponse',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "statusCode": 0,\n  "type": "",\n  "value": {}\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/adaptiveCardInvokeResponse',
  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({statusCode: 0, type: '', value: {}}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse',
  headers: {'content-type': 'application/json'},
  body: {statusCode: 0, type: '', value: {}},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse');

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

req.type('json');
req.send({
  statusCode: 0,
  type: '',
  value: {}
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse',
  headers: {'content-type': 'application/json'},
  data: {statusCode: 0, type: '', value: {}}
};

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

const url = '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"statusCode":0,"type":"","value":{}}'
};

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 = @{ @"statusCode": @0,
                              @"type": @"",
                              @"value": @{  } };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse', [
  'body' => '{
  "statusCode": 0,
  "type": "",
  "value": {}
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'statusCode' => 0,
  'type' => '',
  'value' => [
    
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'statusCode' => 0,
  'type' => '',
  'value' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "statusCode": 0,
  "type": "",
  "value": {}
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "statusCode": 0,
  "type": "",
  "value": {}
}'
import http.client

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

payload = "{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}"

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

conn.request("POST", "/baseUrl/v3/connectorInternals/adaptiveCardInvokeResponse", payload, headers)

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

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

url = "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse"

payload = {
    "statusCode": 0,
    "type": "",
    "value": {}
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse"

payload <- "{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse")

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

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

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

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

response = conn.post('/baseUrl/v3/connectorInternals/adaptiveCardInvokeResponse') do |req|
  req.body = "{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}"
end

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

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

    let payload = json!({
        "statusCode": 0,
        "type": "",
        "value": json!({})
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse \
  --header 'content-type: application/json' \
  --data '{
  "statusCode": 0,
  "type": "",
  "value": {}
}'
echo '{
  "statusCode": 0,
  "type": "",
  "value": {}
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "statusCode": 0,\n  "type": "",\n  "value": {}\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeResponse
import Foundation

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

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

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

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

dataTask.resume()
POST PostAdaptiveCardInvokeValue
{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue
BODY json

{
  "action": {
    "type": "",
    "id": "",
    "verb": "",
    "data": {}
  },
  "authentication": {
    "connectionName": "",
    "token": ""
  },
  "state": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"action\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"verb\": \"\",\n    \"data\": {}\n  },\n  \"authentication\": {\n    \"connectionName\": \"\",\n    \"token\": \"\"\n  },\n  \"state\": \"\"\n}");

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

(client/post "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue" {:content-type :json
                                                                                          :form-params {:action {:type ""
                                                                                                                 :id ""
                                                                                                                 :verb ""
                                                                                                                 :data {}}
                                                                                                        :authentication {:connectionName ""
                                                                                                                         :token ""}
                                                                                                        :state ""}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"action\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"verb\": \"\",\n    \"data\": {}\n  },\n  \"authentication\": {\n    \"connectionName\": \"\",\n    \"token\": \"\"\n  },\n  \"state\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue"),
    Content = new StringContent("{\n  \"action\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"verb\": \"\",\n    \"data\": {}\n  },\n  \"authentication\": {\n    \"connectionName\": \"\",\n    \"token\": \"\"\n  },\n  \"state\": \"\"\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}}/v3/connectorInternals/adaptiveCardInvokeValue");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"action\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"verb\": \"\",\n    \"data\": {}\n  },\n  \"authentication\": {\n    \"connectionName\": \"\",\n    \"token\": \"\"\n  },\n  \"state\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue"

	payload := strings.NewReader("{\n  \"action\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"verb\": \"\",\n    \"data\": {}\n  },\n  \"authentication\": {\n    \"connectionName\": \"\",\n    \"token\": \"\"\n  },\n  \"state\": \"\"\n}")

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

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

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

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

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

}
POST /baseUrl/v3/connectorInternals/adaptiveCardInvokeValue HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 166

{
  "action": {
    "type": "",
    "id": "",
    "verb": "",
    "data": {}
  },
  "authentication": {
    "connectionName": "",
    "token": ""
  },
  "state": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"action\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"verb\": \"\",\n    \"data\": {}\n  },\n  \"authentication\": {\n    \"connectionName\": \"\",\n    \"token\": \"\"\n  },\n  \"state\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"action\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"verb\": \"\",\n    \"data\": {}\n  },\n  \"authentication\": {\n    \"connectionName\": \"\",\n    \"token\": \"\"\n  },\n  \"state\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"action\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"verb\": \"\",\n    \"data\": {}\n  },\n  \"authentication\": {\n    \"connectionName\": \"\",\n    \"token\": \"\"\n  },\n  \"state\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue")
  .header("content-type", "application/json")
  .body("{\n  \"action\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"verb\": \"\",\n    \"data\": {}\n  },\n  \"authentication\": {\n    \"connectionName\": \"\",\n    \"token\": \"\"\n  },\n  \"state\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  action: {
    type: '',
    id: '',
    verb: '',
    data: {}
  },
  authentication: {
    connectionName: '',
    token: ''
  },
  state: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue',
  headers: {'content-type': 'application/json'},
  data: {
    action: {type: '', id: '', verb: '', data: {}},
    authentication: {connectionName: '', token: ''},
    state: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"action":{"type":"","id":"","verb":"","data":{}},"authentication":{"connectionName":"","token":""},"state":""}'
};

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}}/v3/connectorInternals/adaptiveCardInvokeValue',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "action": {\n    "type": "",\n    "id": "",\n    "verb": "",\n    "data": {}\n  },\n  "authentication": {\n    "connectionName": "",\n    "token": ""\n  },\n  "state": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"action\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"verb\": \"\",\n    \"data\": {}\n  },\n  \"authentication\": {\n    \"connectionName\": \"\",\n    \"token\": \"\"\n  },\n  \"state\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

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

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

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

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

req.write(JSON.stringify({
  action: {type: '', id: '', verb: '', data: {}},
  authentication: {connectionName: '', token: ''},
  state: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue',
  headers: {'content-type': 'application/json'},
  body: {
    action: {type: '', id: '', verb: '', data: {}},
    authentication: {connectionName: '', token: ''},
    state: ''
  },
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue');

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

req.type('json');
req.send({
  action: {
    type: '',
    id: '',
    verb: '',
    data: {}
  },
  authentication: {
    connectionName: '',
    token: ''
  },
  state: ''
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue',
  headers: {'content-type': 'application/json'},
  data: {
    action: {type: '', id: '', verb: '', data: {}},
    authentication: {connectionName: '', token: ''},
    state: ''
  }
};

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

const url = '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"action":{"type":"","id":"","verb":"","data":{}},"authentication":{"connectionName":"","token":""},"state":""}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"action": @{ @"type": @"", @"id": @"", @"verb": @"", @"data": @{  } },
                              @"authentication": @{ @"connectionName": @"", @"token": @"" },
                              @"state": @"" };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"action\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"verb\": \"\",\n    \"data\": {}\n  },\n  \"authentication\": {\n    \"connectionName\": \"\",\n    \"token\": \"\"\n  },\n  \"state\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'action' => [
        'type' => '',
        'id' => '',
        'verb' => '',
        'data' => [
                
        ]
    ],
    'authentication' => [
        'connectionName' => '',
        'token' => ''
    ],
    'state' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue', [
  'body' => '{
  "action": {
    "type": "",
    "id": "",
    "verb": "",
    "data": {}
  },
  "authentication": {
    "connectionName": "",
    "token": ""
  },
  "state": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'action' => [
    'type' => '',
    'id' => '',
    'verb' => '',
    'data' => [
        
    ]
  ],
  'authentication' => [
    'connectionName' => '',
    'token' => ''
  ],
  'state' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'action' => [
    'type' => '',
    'id' => '',
    'verb' => '',
    'data' => [
        
    ]
  ],
  'authentication' => [
    'connectionName' => '',
    'token' => ''
  ],
  'state' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "action": {
    "type": "",
    "id": "",
    "verb": "",
    "data": {}
  },
  "authentication": {
    "connectionName": "",
    "token": ""
  },
  "state": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "action": {
    "type": "",
    "id": "",
    "verb": "",
    "data": {}
  },
  "authentication": {
    "connectionName": "",
    "token": ""
  },
  "state": ""
}'
import http.client

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

payload = "{\n  \"action\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"verb\": \"\",\n    \"data\": {}\n  },\n  \"authentication\": {\n    \"connectionName\": \"\",\n    \"token\": \"\"\n  },\n  \"state\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v3/connectorInternals/adaptiveCardInvokeValue", payload, headers)

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

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

url = "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue"

payload = {
    "action": {
        "type": "",
        "id": "",
        "verb": "",
        "data": {}
    },
    "authentication": {
        "connectionName": "",
        "token": ""
    },
    "state": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue"

payload <- "{\n  \"action\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"verb\": \"\",\n    \"data\": {}\n  },\n  \"authentication\": {\n    \"connectionName\": \"\",\n    \"token\": \"\"\n  },\n  \"state\": \"\"\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue")

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

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"action\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"verb\": \"\",\n    \"data\": {}\n  },\n  \"authentication\": {\n    \"connectionName\": \"\",\n    \"token\": \"\"\n  },\n  \"state\": \"\"\n}"

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

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

response = conn.post('/baseUrl/v3/connectorInternals/adaptiveCardInvokeValue') do |req|
  req.body = "{\n  \"action\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"verb\": \"\",\n    \"data\": {}\n  },\n  \"authentication\": {\n    \"connectionName\": \"\",\n    \"token\": \"\"\n  },\n  \"state\": \"\"\n}"
end

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

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

    let payload = json!({
        "action": json!({
            "type": "",
            "id": "",
            "verb": "",
            "data": json!({})
        }),
        "authentication": json!({
            "connectionName": "",
            "token": ""
        }),
        "state": ""
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue \
  --header 'content-type: application/json' \
  --data '{
  "action": {
    "type": "",
    "id": "",
    "verb": "",
    "data": {}
  },
  "authentication": {
    "connectionName": "",
    "token": ""
  },
  "state": ""
}'
echo '{
  "action": {
    "type": "",
    "id": "",
    "verb": "",
    "data": {}
  },
  "authentication": {
    "connectionName": "",
    "token": ""
  },
  "state": ""
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "action": {\n    "type": "",\n    "id": "",\n    "verb": "",\n    "data": {}\n  },\n  "authentication": {\n    "connectionName": "",\n    "token": ""\n  },\n  "state": ""\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/adaptiveCardInvokeValue
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "action": [
    "type": "",
    "id": "",
    "verb": "",
    "data": []
  ],
  "authentication": [
    "connectionName": "",
    "token": ""
  ],
  "state": ""
] as [String : Any]

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

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

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

dataTask.resume()
POST PostAnimationCard
{{baseUrl}}/v3/connectorInternals/animationCard
BODY json

{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/animationCard");

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  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}");

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

(client/post "{{baseUrl}}/v3/connectorInternals/animationCard" {:content-type :json
                                                                                :form-params {:title ""
                                                                                              :subtitle ""
                                                                                              :text ""
                                                                                              :image {:url ""
                                                                                                      :alt ""}
                                                                                              :media [{:url ""
                                                                                                       :profile ""}]
                                                                                              :buttons [{:type ""
                                                                                                         :title ""
                                                                                                         :image ""
                                                                                                         :imageAltText ""
                                                                                                         :text ""
                                                                                                         :displayText ""
                                                                                                         :value {}
                                                                                                         :channelData {}}]
                                                                                              :shareable false
                                                                                              :autoloop false
                                                                                              :autostart false
                                                                                              :aspect ""
                                                                                              :duration ""
                                                                                              :value {}}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/animationCard"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/animationCard"),
    Content = new StringContent("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\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}}/v3/connectorInternals/animationCard");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/animationCard"

	payload := strings.NewReader("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}")

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

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

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

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

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

}
POST /baseUrl/v3/connectorInternals/animationCard HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 477

{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/animationCard")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/animationCard"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\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  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/animationCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/animationCard")
  .header("content-type", "application/json")
  .body("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}")
  .asString();
const data = JSON.stringify({
  title: '',
  subtitle: '',
  text: '',
  image: {
    url: '',
    alt: ''
  },
  media: [
    {
      url: '',
      profile: ''
    }
  ],
  buttons: [
    {
      type: '',
      title: '',
      image: '',
      imageAltText: '',
      text: '',
      displayText: '',
      value: {},
      channelData: {}
    }
  ],
  shareable: false,
  autoloop: false,
  autostart: false,
  aspect: '',
  duration: '',
  value: {}
});

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

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

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/animationCard');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/animationCard',
  headers: {'content-type': 'application/json'},
  data: {
    title: '',
    subtitle: '',
    text: '',
    image: {url: '', alt: ''},
    media: [{url: '', profile: ''}],
    buttons: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ],
    shareable: false,
    autoloop: false,
    autostart: false,
    aspect: '',
    duration: '',
    value: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/animationCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"title":"","subtitle":"","text":"","image":{"url":"","alt":""},"media":[{"url":"","profile":""}],"buttons":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}],"shareable":false,"autoloop":false,"autostart":false,"aspect":"","duration":"","value":{}}'
};

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}}/v3/connectorInternals/animationCard',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "title": "",\n  "subtitle": "",\n  "text": "",\n  "image": {\n    "url": "",\n    "alt": ""\n  },\n  "media": [\n    {\n      "url": "",\n      "profile": ""\n    }\n  ],\n  "buttons": [\n    {\n      "type": "",\n      "title": "",\n      "image": "",\n      "imageAltText": "",\n      "text": "",\n      "displayText": "",\n      "value": {},\n      "channelData": {}\n    }\n  ],\n  "shareable": false,\n  "autoloop": false,\n  "autostart": false,\n  "aspect": "",\n  "duration": "",\n  "value": {}\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/animationCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/animationCard',
  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({
  title: '',
  subtitle: '',
  text: '',
  image: {url: '', alt: ''},
  media: [{url: '', profile: ''}],
  buttons: [
    {
      type: '',
      title: '',
      image: '',
      imageAltText: '',
      text: '',
      displayText: '',
      value: {},
      channelData: {}
    }
  ],
  shareable: false,
  autoloop: false,
  autostart: false,
  aspect: '',
  duration: '',
  value: {}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/animationCard',
  headers: {'content-type': 'application/json'},
  body: {
    title: '',
    subtitle: '',
    text: '',
    image: {url: '', alt: ''},
    media: [{url: '', profile: ''}],
    buttons: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ],
    shareable: false,
    autoloop: false,
    autostart: false,
    aspect: '',
    duration: '',
    value: {}
  },
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/animationCard');

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

req.type('json');
req.send({
  title: '',
  subtitle: '',
  text: '',
  image: {
    url: '',
    alt: ''
  },
  media: [
    {
      url: '',
      profile: ''
    }
  ],
  buttons: [
    {
      type: '',
      title: '',
      image: '',
      imageAltText: '',
      text: '',
      displayText: '',
      value: {},
      channelData: {}
    }
  ],
  shareable: false,
  autoloop: false,
  autostart: false,
  aspect: '',
  duration: '',
  value: {}
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/animationCard',
  headers: {'content-type': 'application/json'},
  data: {
    title: '',
    subtitle: '',
    text: '',
    image: {url: '', alt: ''},
    media: [{url: '', profile: ''}],
    buttons: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ],
    shareable: false,
    autoloop: false,
    autostart: false,
    aspect: '',
    duration: '',
    value: {}
  }
};

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

const url = '{{baseUrl}}/v3/connectorInternals/animationCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"title":"","subtitle":"","text":"","image":{"url":"","alt":""},"media":[{"url":"","profile":""}],"buttons":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}],"shareable":false,"autoloop":false,"autostart":false,"aspect":"","duration":"","value":{}}'
};

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 = @{ @"title": @"",
                              @"subtitle": @"",
                              @"text": @"",
                              @"image": @{ @"url": @"", @"alt": @"" },
                              @"media": @[ @{ @"url": @"", @"profile": @"" } ],
                              @"buttons": @[ @{ @"type": @"", @"title": @"", @"image": @"", @"imageAltText": @"", @"text": @"", @"displayText": @"", @"value": @{  }, @"channelData": @{  } } ],
                              @"shareable": @NO,
                              @"autoloop": @NO,
                              @"autostart": @NO,
                              @"aspect": @"",
                              @"duration": @"",
                              @"value": @{  } };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/animationCard" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/animationCard",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'title' => '',
    'subtitle' => '',
    'text' => '',
    'image' => [
        'url' => '',
        'alt' => ''
    ],
    'media' => [
        [
                'url' => '',
                'profile' => ''
        ]
    ],
    'buttons' => [
        [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ],
    'shareable' => null,
    'autoloop' => null,
    'autostart' => null,
    'aspect' => '',
    'duration' => '',
    'value' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/animationCard', [
  'body' => '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/animationCard');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'title' => '',
  'subtitle' => '',
  'text' => '',
  'image' => [
    'url' => '',
    'alt' => ''
  ],
  'media' => [
    [
        'url' => '',
        'profile' => ''
    ]
  ],
  'buttons' => [
    [
        'type' => '',
        'title' => '',
        'image' => '',
        'imageAltText' => '',
        'text' => '',
        'displayText' => '',
        'value' => [
                
        ],
        'channelData' => [
                
        ]
    ]
  ],
  'shareable' => null,
  'autoloop' => null,
  'autostart' => null,
  'aspect' => '',
  'duration' => '',
  'value' => [
    
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'title' => '',
  'subtitle' => '',
  'text' => '',
  'image' => [
    'url' => '',
    'alt' => ''
  ],
  'media' => [
    [
        'url' => '',
        'profile' => ''
    ]
  ],
  'buttons' => [
    [
        'type' => '',
        'title' => '',
        'image' => '',
        'imageAltText' => '',
        'text' => '',
        'displayText' => '',
        'value' => [
                
        ],
        'channelData' => [
                
        ]
    ]
  ],
  'shareable' => null,
  'autoloop' => null,
  'autostart' => null,
  'aspect' => '',
  'duration' => '',
  'value' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/animationCard');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/animationCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/animationCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}'
import http.client

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

payload = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"

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

conn.request("POST", "/baseUrl/v3/connectorInternals/animationCard", payload, headers)

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

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

url = "{{baseUrl}}/v3/connectorInternals/animationCard"

payload = {
    "title": "",
    "subtitle": "",
    "text": "",
    "image": {
        "url": "",
        "alt": ""
    },
    "media": [
        {
            "url": "",
            "profile": ""
        }
    ],
    "buttons": [
        {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
        }
    ],
    "shareable": False,
    "autoloop": False,
    "autostart": False,
    "aspect": "",
    "duration": "",
    "value": {}
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3/connectorInternals/animationCard"

payload <- "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v3/connectorInternals/animationCard")

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

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"

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

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

response = conn.post('/baseUrl/v3/connectorInternals/animationCard') do |req|
  req.body = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"
end

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

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

    let payload = json!({
        "title": "",
        "subtitle": "",
        "text": "",
        "image": json!({
            "url": "",
            "alt": ""
        }),
        "media": (
            json!({
                "url": "",
                "profile": ""
            })
        ),
        "buttons": (
            json!({
                "type": "",
                "title": "",
                "image": "",
                "imageAltText": "",
                "text": "",
                "displayText": "",
                "value": json!({}),
                "channelData": json!({})
            })
        ),
        "shareable": false,
        "autoloop": false,
        "autostart": false,
        "aspect": "",
        "duration": "",
        "value": json!({})
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/animationCard \
  --header 'content-type: application/json' \
  --data '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}'
echo '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/animationCard \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "title": "",\n  "subtitle": "",\n  "text": "",\n  "image": {\n    "url": "",\n    "alt": ""\n  },\n  "media": [\n    {\n      "url": "",\n      "profile": ""\n    }\n  ],\n  "buttons": [\n    {\n      "type": "",\n      "title": "",\n      "image": "",\n      "imageAltText": "",\n      "text": "",\n      "displayText": "",\n      "value": {},\n      "channelData": {}\n    }\n  ],\n  "shareable": false,\n  "autoloop": false,\n  "autostart": false,\n  "aspect": "",\n  "duration": "",\n  "value": {}\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/animationCard
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "title": "",
  "subtitle": "",
  "text": "",
  "image": [
    "url": "",
    "alt": ""
  ],
  "media": [
    [
      "url": "",
      "profile": ""
    ]
  ],
  "buttons": [
    [
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": [],
      "channelData": []
    ]
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": []
] as [String : Any]

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

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

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

dataTask.resume()
POST PostAttachmentInfo
{{baseUrl}}/v3/connectorInternals/attachmentInfo
BODY json

{
  "name": "",
  "type": "",
  "views": [
    {
      "viewId": "",
      "size": 0
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/attachmentInfo");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"name\": \"\",\n  \"type\": \"\",\n  \"views\": [\n    {\n      \"viewId\": \"\",\n      \"size\": 0\n    }\n  ]\n}");

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

(client/post "{{baseUrl}}/v3/connectorInternals/attachmentInfo" {:content-type :json
                                                                                 :form-params {:name ""
                                                                                               :type ""
                                                                                               :views [{:viewId ""
                                                                                                        :size 0}]}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/attachmentInfo"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"name\": \"\",\n  \"type\": \"\",\n  \"views\": [\n    {\n      \"viewId\": \"\",\n      \"size\": 0\n    }\n  ]\n}"

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

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

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/attachmentInfo"

	payload := strings.NewReader("{\n  \"name\": \"\",\n  \"type\": \"\",\n  \"views\": [\n    {\n      \"viewId\": \"\",\n      \"size\": 0\n    }\n  ]\n}")

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

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

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

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

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

}
POST /baseUrl/v3/connectorInternals/attachmentInfo HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 96

{
  "name": "",
  "type": "",
  "views": [
    {
      "viewId": "",
      "size": 0
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/attachmentInfo")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"name\": \"\",\n  \"type\": \"\",\n  \"views\": [\n    {\n      \"viewId\": \"\",\n      \"size\": 0\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/attachmentInfo"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"name\": \"\",\n  \"type\": \"\",\n  \"views\": [\n    {\n      \"viewId\": \"\",\n      \"size\": 0\n    }\n  ]\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"name\": \"\",\n  \"type\": \"\",\n  \"views\": [\n    {\n      \"viewId\": \"\",\n      \"size\": 0\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/attachmentInfo")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/attachmentInfo")
  .header("content-type", "application/json")
  .body("{\n  \"name\": \"\",\n  \"type\": \"\",\n  \"views\": [\n    {\n      \"viewId\": \"\",\n      \"size\": 0\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  name: '',
  type: '',
  views: [
    {
      viewId: '',
      size: 0
    }
  ]
});

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

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

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/attachmentInfo');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/attachmentInfo',
  headers: {'content-type': 'application/json'},
  data: {name: '', type: '', views: [{viewId: '', size: 0}]}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/attachmentInfo';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","type":"","views":[{"viewId":"","size":0}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v3/connectorInternals/attachmentInfo',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "name": "",\n  "type": "",\n  "views": [\n    {\n      "viewId": "",\n      "size": 0\n    }\n  ]\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"name\": \"\",\n  \"type\": \"\",\n  \"views\": [\n    {\n      \"viewId\": \"\",\n      \"size\": 0\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/attachmentInfo")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

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

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

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

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

req.write(JSON.stringify({name: '', type: '', views: [{viewId: '', size: 0}]}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/attachmentInfo',
  headers: {'content-type': 'application/json'},
  body: {name: '', type: '', views: [{viewId: '', size: 0}]},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/attachmentInfo');

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

req.type('json');
req.send({
  name: '',
  type: '',
  views: [
    {
      viewId: '',
      size: 0
    }
  ]
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/attachmentInfo',
  headers: {'content-type': 'application/json'},
  data: {name: '', type: '', views: [{viewId: '', size: 0}]}
};

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

const url = '{{baseUrl}}/v3/connectorInternals/attachmentInfo';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","type":"","views":[{"viewId":"","size":0}]}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"name": @"",
                              @"type": @"",
                              @"views": @[ @{ @"viewId": @"", @"size": @0 } ] };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/attachmentInfo" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"name\": \"\",\n  \"type\": \"\",\n  \"views\": [\n    {\n      \"viewId\": \"\",\n      \"size\": 0\n    }\n  ]\n}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/attachmentInfo', [
  'body' => '{
  "name": "",
  "type": "",
  "views": [
    {
      "viewId": "",
      "size": 0
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/attachmentInfo');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'name' => '',
  'type' => '',
  'views' => [
    [
        'viewId' => '',
        'size' => 0
    ]
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'name' => '',
  'type' => '',
  'views' => [
    [
        'viewId' => '',
        'size' => 0
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/attachmentInfo');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/attachmentInfo' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "type": "",
  "views": [
    {
      "viewId": "",
      "size": 0
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/attachmentInfo' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "type": "",
  "views": [
    {
      "viewId": "",
      "size": 0
    }
  ]
}'
import http.client

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

payload = "{\n  \"name\": \"\",\n  \"type\": \"\",\n  \"views\": [\n    {\n      \"viewId\": \"\",\n      \"size\": 0\n    }\n  ]\n}"

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

conn.request("POST", "/baseUrl/v3/connectorInternals/attachmentInfo", payload, headers)

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

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

url = "{{baseUrl}}/v3/connectorInternals/attachmentInfo"

payload = {
    "name": "",
    "type": "",
    "views": [
        {
            "viewId": "",
            "size": 0
        }
    ]
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3/connectorInternals/attachmentInfo"

payload <- "{\n  \"name\": \"\",\n  \"type\": \"\",\n  \"views\": [\n    {\n      \"viewId\": \"\",\n      \"size\": 0\n    }\n  ]\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v3/connectorInternals/attachmentInfo")

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

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"name\": \"\",\n  \"type\": \"\",\n  \"views\": [\n    {\n      \"viewId\": \"\",\n      \"size\": 0\n    }\n  ]\n}"

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

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

response = conn.post('/baseUrl/v3/connectorInternals/attachmentInfo') do |req|
  req.body = "{\n  \"name\": \"\",\n  \"type\": \"\",\n  \"views\": [\n    {\n      \"viewId\": \"\",\n      \"size\": 0\n    }\n  ]\n}"
end

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

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

    let payload = json!({
        "name": "",
        "type": "",
        "views": (
            json!({
                "viewId": "",
                "size": 0
            })
        )
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/attachmentInfo \
  --header 'content-type: application/json' \
  --data '{
  "name": "",
  "type": "",
  "views": [
    {
      "viewId": "",
      "size": 0
    }
  ]
}'
echo '{
  "name": "",
  "type": "",
  "views": [
    {
      "viewId": "",
      "size": 0
    }
  ]
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/attachmentInfo \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "name": "",\n  "type": "",\n  "views": [\n    {\n      "viewId": "",\n      "size": 0\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/attachmentInfo
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "name": "",
  "type": "",
  "views": [
    [
      "viewId": "",
      "size": 0
    ]
  ]
] as [String : Any]

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

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

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

dataTask.resume()
POST PostAudioCard
{{baseUrl}}/v3/connectorInternals/audioCard
BODY json

{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/audioCard");

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  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}");

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

(client/post "{{baseUrl}}/v3/connectorInternals/audioCard" {:content-type :json
                                                                            :form-params {:title ""
                                                                                          :subtitle ""
                                                                                          :text ""
                                                                                          :image {:url ""
                                                                                                  :alt ""}
                                                                                          :media [{:url ""
                                                                                                   :profile ""}]
                                                                                          :buttons [{:type ""
                                                                                                     :title ""
                                                                                                     :image ""
                                                                                                     :imageAltText ""
                                                                                                     :text ""
                                                                                                     :displayText ""
                                                                                                     :value {}
                                                                                                     :channelData {}}]
                                                                                          :shareable false
                                                                                          :autoloop false
                                                                                          :autostart false
                                                                                          :aspect ""
                                                                                          :duration ""
                                                                                          :value {}}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/audioCard"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/audioCard"),
    Content = new StringContent("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\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}}/v3/connectorInternals/audioCard");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/audioCard"

	payload := strings.NewReader("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}")

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

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

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

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

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

}
POST /baseUrl/v3/connectorInternals/audioCard HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 477

{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/audioCard")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/audioCard"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\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  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/audioCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/audioCard")
  .header("content-type", "application/json")
  .body("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}")
  .asString();
const data = JSON.stringify({
  title: '',
  subtitle: '',
  text: '',
  image: {
    url: '',
    alt: ''
  },
  media: [
    {
      url: '',
      profile: ''
    }
  ],
  buttons: [
    {
      type: '',
      title: '',
      image: '',
      imageAltText: '',
      text: '',
      displayText: '',
      value: {},
      channelData: {}
    }
  ],
  shareable: false,
  autoloop: false,
  autostart: false,
  aspect: '',
  duration: '',
  value: {}
});

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

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

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/audioCard');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/audioCard',
  headers: {'content-type': 'application/json'},
  data: {
    title: '',
    subtitle: '',
    text: '',
    image: {url: '', alt: ''},
    media: [{url: '', profile: ''}],
    buttons: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ],
    shareable: false,
    autoloop: false,
    autostart: false,
    aspect: '',
    duration: '',
    value: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/audioCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"title":"","subtitle":"","text":"","image":{"url":"","alt":""},"media":[{"url":"","profile":""}],"buttons":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}],"shareable":false,"autoloop":false,"autostart":false,"aspect":"","duration":"","value":{}}'
};

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}}/v3/connectorInternals/audioCard',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "title": "",\n  "subtitle": "",\n  "text": "",\n  "image": {\n    "url": "",\n    "alt": ""\n  },\n  "media": [\n    {\n      "url": "",\n      "profile": ""\n    }\n  ],\n  "buttons": [\n    {\n      "type": "",\n      "title": "",\n      "image": "",\n      "imageAltText": "",\n      "text": "",\n      "displayText": "",\n      "value": {},\n      "channelData": {}\n    }\n  ],\n  "shareable": false,\n  "autoloop": false,\n  "autostart": false,\n  "aspect": "",\n  "duration": "",\n  "value": {}\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/audioCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/audioCard',
  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({
  title: '',
  subtitle: '',
  text: '',
  image: {url: '', alt: ''},
  media: [{url: '', profile: ''}],
  buttons: [
    {
      type: '',
      title: '',
      image: '',
      imageAltText: '',
      text: '',
      displayText: '',
      value: {},
      channelData: {}
    }
  ],
  shareable: false,
  autoloop: false,
  autostart: false,
  aspect: '',
  duration: '',
  value: {}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/audioCard',
  headers: {'content-type': 'application/json'},
  body: {
    title: '',
    subtitle: '',
    text: '',
    image: {url: '', alt: ''},
    media: [{url: '', profile: ''}],
    buttons: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ],
    shareable: false,
    autoloop: false,
    autostart: false,
    aspect: '',
    duration: '',
    value: {}
  },
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/audioCard');

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

req.type('json');
req.send({
  title: '',
  subtitle: '',
  text: '',
  image: {
    url: '',
    alt: ''
  },
  media: [
    {
      url: '',
      profile: ''
    }
  ],
  buttons: [
    {
      type: '',
      title: '',
      image: '',
      imageAltText: '',
      text: '',
      displayText: '',
      value: {},
      channelData: {}
    }
  ],
  shareable: false,
  autoloop: false,
  autostart: false,
  aspect: '',
  duration: '',
  value: {}
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/audioCard',
  headers: {'content-type': 'application/json'},
  data: {
    title: '',
    subtitle: '',
    text: '',
    image: {url: '', alt: ''},
    media: [{url: '', profile: ''}],
    buttons: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ],
    shareable: false,
    autoloop: false,
    autostart: false,
    aspect: '',
    duration: '',
    value: {}
  }
};

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

const url = '{{baseUrl}}/v3/connectorInternals/audioCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"title":"","subtitle":"","text":"","image":{"url":"","alt":""},"media":[{"url":"","profile":""}],"buttons":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}],"shareable":false,"autoloop":false,"autostart":false,"aspect":"","duration":"","value":{}}'
};

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 = @{ @"title": @"",
                              @"subtitle": @"",
                              @"text": @"",
                              @"image": @{ @"url": @"", @"alt": @"" },
                              @"media": @[ @{ @"url": @"", @"profile": @"" } ],
                              @"buttons": @[ @{ @"type": @"", @"title": @"", @"image": @"", @"imageAltText": @"", @"text": @"", @"displayText": @"", @"value": @{  }, @"channelData": @{  } } ],
                              @"shareable": @NO,
                              @"autoloop": @NO,
                              @"autostart": @NO,
                              @"aspect": @"",
                              @"duration": @"",
                              @"value": @{  } };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/audioCard" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/audioCard",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'title' => '',
    'subtitle' => '',
    'text' => '',
    'image' => [
        'url' => '',
        'alt' => ''
    ],
    'media' => [
        [
                'url' => '',
                'profile' => ''
        ]
    ],
    'buttons' => [
        [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ],
    'shareable' => null,
    'autoloop' => null,
    'autostart' => null,
    'aspect' => '',
    'duration' => '',
    'value' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/audioCard', [
  'body' => '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/audioCard');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'title' => '',
  'subtitle' => '',
  'text' => '',
  'image' => [
    'url' => '',
    'alt' => ''
  ],
  'media' => [
    [
        'url' => '',
        'profile' => ''
    ]
  ],
  'buttons' => [
    [
        'type' => '',
        'title' => '',
        'image' => '',
        'imageAltText' => '',
        'text' => '',
        'displayText' => '',
        'value' => [
                
        ],
        'channelData' => [
                
        ]
    ]
  ],
  'shareable' => null,
  'autoloop' => null,
  'autostart' => null,
  'aspect' => '',
  'duration' => '',
  'value' => [
    
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'title' => '',
  'subtitle' => '',
  'text' => '',
  'image' => [
    'url' => '',
    'alt' => ''
  ],
  'media' => [
    [
        'url' => '',
        'profile' => ''
    ]
  ],
  'buttons' => [
    [
        'type' => '',
        'title' => '',
        'image' => '',
        'imageAltText' => '',
        'text' => '',
        'displayText' => '',
        'value' => [
                
        ],
        'channelData' => [
                
        ]
    ]
  ],
  'shareable' => null,
  'autoloop' => null,
  'autostart' => null,
  'aspect' => '',
  'duration' => '',
  'value' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/audioCard');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/audioCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/audioCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}'
import http.client

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

payload = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"

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

conn.request("POST", "/baseUrl/v3/connectorInternals/audioCard", payload, headers)

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

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

url = "{{baseUrl}}/v3/connectorInternals/audioCard"

payload = {
    "title": "",
    "subtitle": "",
    "text": "",
    "image": {
        "url": "",
        "alt": ""
    },
    "media": [
        {
            "url": "",
            "profile": ""
        }
    ],
    "buttons": [
        {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
        }
    ],
    "shareable": False,
    "autoloop": False,
    "autostart": False,
    "aspect": "",
    "duration": "",
    "value": {}
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3/connectorInternals/audioCard"

payload <- "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v3/connectorInternals/audioCard")

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

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"

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

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

response = conn.post('/baseUrl/v3/connectorInternals/audioCard') do |req|
  req.body = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"
end

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

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

    let payload = json!({
        "title": "",
        "subtitle": "",
        "text": "",
        "image": json!({
            "url": "",
            "alt": ""
        }),
        "media": (
            json!({
                "url": "",
                "profile": ""
            })
        ),
        "buttons": (
            json!({
                "type": "",
                "title": "",
                "image": "",
                "imageAltText": "",
                "text": "",
                "displayText": "",
                "value": json!({}),
                "channelData": json!({})
            })
        ),
        "shareable": false,
        "autoloop": false,
        "autostart": false,
        "aspect": "",
        "duration": "",
        "value": json!({})
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/audioCard \
  --header 'content-type: application/json' \
  --data '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}'
echo '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/audioCard \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "title": "",\n  "subtitle": "",\n  "text": "",\n  "image": {\n    "url": "",\n    "alt": ""\n  },\n  "media": [\n    {\n      "url": "",\n      "profile": ""\n    }\n  ],\n  "buttons": [\n    {\n      "type": "",\n      "title": "",\n      "image": "",\n      "imageAltText": "",\n      "text": "",\n      "displayText": "",\n      "value": {},\n      "channelData": {}\n    }\n  ],\n  "shareable": false,\n  "autoloop": false,\n  "autostart": false,\n  "aspect": "",\n  "duration": "",\n  "value": {}\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/audioCard
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "title": "",
  "subtitle": "",
  "text": "",
  "image": [
    "url": "",
    "alt": ""
  ],
  "media": [
    [
      "url": "",
      "profile": ""
    ]
  ],
  "buttons": [
    [
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": [],
      "channelData": []
    ]
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": []
] as [String : Any]

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

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

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

dataTask.resume()
POST PostBasicCard
{{baseUrl}}/v3/connectorInternals/basicCard
BODY json

{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/basicCard");

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  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}");

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

(client/post "{{baseUrl}}/v3/connectorInternals/basicCard" {:content-type :json
                                                                            :form-params {:title ""
                                                                                          :subtitle ""
                                                                                          :text ""
                                                                                          :images [{:url ""
                                                                                                    :alt ""
                                                                                                    :tap {:type ""
                                                                                                          :title ""
                                                                                                          :image ""
                                                                                                          :imageAltText ""
                                                                                                          :text ""
                                                                                                          :displayText ""
                                                                                                          :value {}
                                                                                                          :channelData {}}}]
                                                                                          :buttons [{}]
                                                                                          :tap {}}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/basicCard"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/basicCard"),
    Content = new StringContent("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\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}}/v3/connectorInternals/basicCard");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/basicCard"

	payload := strings.NewReader("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}")

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

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

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

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

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

}
POST /baseUrl/v3/connectorInternals/basicCard HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 361

{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/basicCard")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/basicCard"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\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  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/basicCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/basicCard")
  .header("content-type", "application/json")
  .body("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}")
  .asString();
const data = JSON.stringify({
  title: '',
  subtitle: '',
  text: '',
  images: [
    {
      url: '',
      alt: '',
      tap: {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    }
  ],
  buttons: [
    {}
  ],
  tap: {}
});

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

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

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/basicCard');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/basicCard',
  headers: {'content-type': 'application/json'},
  data: {
    title: '',
    subtitle: '',
    text: '',
    images: [
      {
        url: '',
        alt: '',
        tap: {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      }
    ],
    buttons: [{}],
    tap: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/basicCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"title":"","subtitle":"","text":"","images":[{"url":"","alt":"","tap":{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}}],"buttons":[{}],"tap":{}}'
};

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}}/v3/connectorInternals/basicCard',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "title": "",\n  "subtitle": "",\n  "text": "",\n  "images": [\n    {\n      "url": "",\n      "alt": "",\n      "tap": {\n        "type": "",\n        "title": "",\n        "image": "",\n        "imageAltText": "",\n        "text": "",\n        "displayText": "",\n        "value": {},\n        "channelData": {}\n      }\n    }\n  ],\n  "buttons": [\n    {}\n  ],\n  "tap": {}\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/basicCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/basicCard',
  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({
  title: '',
  subtitle: '',
  text: '',
  images: [
    {
      url: '',
      alt: '',
      tap: {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    }
  ],
  buttons: [{}],
  tap: {}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/basicCard',
  headers: {'content-type': 'application/json'},
  body: {
    title: '',
    subtitle: '',
    text: '',
    images: [
      {
        url: '',
        alt: '',
        tap: {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      }
    ],
    buttons: [{}],
    tap: {}
  },
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/basicCard');

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

req.type('json');
req.send({
  title: '',
  subtitle: '',
  text: '',
  images: [
    {
      url: '',
      alt: '',
      tap: {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    }
  ],
  buttons: [
    {}
  ],
  tap: {}
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/basicCard',
  headers: {'content-type': 'application/json'},
  data: {
    title: '',
    subtitle: '',
    text: '',
    images: [
      {
        url: '',
        alt: '',
        tap: {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      }
    ],
    buttons: [{}],
    tap: {}
  }
};

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

const url = '{{baseUrl}}/v3/connectorInternals/basicCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"title":"","subtitle":"","text":"","images":[{"url":"","alt":"","tap":{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}}],"buttons":[{}],"tap":{}}'
};

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 = @{ @"title": @"",
                              @"subtitle": @"",
                              @"text": @"",
                              @"images": @[ @{ @"url": @"", @"alt": @"", @"tap": @{ @"type": @"", @"title": @"", @"image": @"", @"imageAltText": @"", @"text": @"", @"displayText": @"", @"value": @{  }, @"channelData": @{  } } } ],
                              @"buttons": @[ @{  } ],
                              @"tap": @{  } };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/basicCard" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/basicCard",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'title' => '',
    'subtitle' => '',
    'text' => '',
    'images' => [
        [
                'url' => '',
                'alt' => '',
                'tap' => [
                                'type' => '',
                                'title' => '',
                                'image' => '',
                                'imageAltText' => '',
                                'text' => '',
                                'displayText' => '',
                                'value' => [
                                                                
                                ],
                                'channelData' => [
                                                                
                                ]
                ]
        ]
    ],
    'buttons' => [
        [
                
        ]
    ],
    'tap' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/basicCard', [
  'body' => '{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/basicCard');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'title' => '',
  'subtitle' => '',
  'text' => '',
  'images' => [
    [
        'url' => '',
        'alt' => '',
        'tap' => [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ]
  ],
  'buttons' => [
    [
        
    ]
  ],
  'tap' => [
    
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'title' => '',
  'subtitle' => '',
  'text' => '',
  'images' => [
    [
        'url' => '',
        'alt' => '',
        'tap' => [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ]
  ],
  'buttons' => [
    [
        
    ]
  ],
  'tap' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/basicCard');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/basicCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/basicCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}'
import http.client

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

payload = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}"

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

conn.request("POST", "/baseUrl/v3/connectorInternals/basicCard", payload, headers)

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

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

url = "{{baseUrl}}/v3/connectorInternals/basicCard"

payload = {
    "title": "",
    "subtitle": "",
    "text": "",
    "images": [
        {
            "url": "",
            "alt": "",
            "tap": {
                "type": "",
                "title": "",
                "image": "",
                "imageAltText": "",
                "text": "",
                "displayText": "",
                "value": {},
                "channelData": {}
            }
        }
    ],
    "buttons": [{}],
    "tap": {}
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3/connectorInternals/basicCard"

payload <- "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v3/connectorInternals/basicCard")

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

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}"

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

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

response = conn.post('/baseUrl/v3/connectorInternals/basicCard') do |req|
  req.body = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}"
end

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

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

    let payload = json!({
        "title": "",
        "subtitle": "",
        "text": "",
        "images": (
            json!({
                "url": "",
                "alt": "",
                "tap": json!({
                    "type": "",
                    "title": "",
                    "image": "",
                    "imageAltText": "",
                    "text": "",
                    "displayText": "",
                    "value": json!({}),
                    "channelData": json!({})
                })
            })
        ),
        "buttons": (json!({})),
        "tap": json!({})
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/basicCard \
  --header 'content-type: application/json' \
  --data '{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}'
echo '{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/basicCard \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "title": "",\n  "subtitle": "",\n  "text": "",\n  "images": [\n    {\n      "url": "",\n      "alt": "",\n      "tap": {\n        "type": "",\n        "title": "",\n        "image": "",\n        "imageAltText": "",\n        "text": "",\n        "displayText": "",\n        "value": {},\n        "channelData": {}\n      }\n    }\n  ],\n  "buttons": [\n    {}\n  ],\n  "tap": {}\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/basicCard
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    [
      "url": "",
      "alt": "",
      "tap": [
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": [],
        "channelData": []
      ]
    ]
  ],
  "buttons": [[]],
  "tap": []
] as [String : Any]

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

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

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

dataTask.resume()
POST PostConversationResourceResponse
{{baseUrl}}/v3/connectorInternals/conversationResourceResponse
BODY json

{
  "activityId": "",
  "serviceUrl": "",
  "id": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/conversationResourceResponse");

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  \"activityId\": \"\",\n  \"serviceUrl\": \"\",\n  \"id\": \"\"\n}");

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

(client/post "{{baseUrl}}/v3/connectorInternals/conversationResourceResponse" {:content-type :json
                                                                                               :form-params {:activityId ""
                                                                                                             :serviceUrl ""
                                                                                                             :id ""}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/conversationResourceResponse"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"activityId\": \"\",\n  \"serviceUrl\": \"\",\n  \"id\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/conversationResourceResponse"),
    Content = new StringContent("{\n  \"activityId\": \"\",\n  \"serviceUrl\": \"\",\n  \"id\": \"\"\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}}/v3/connectorInternals/conversationResourceResponse");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"activityId\": \"\",\n  \"serviceUrl\": \"\",\n  \"id\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/conversationResourceResponse"

	payload := strings.NewReader("{\n  \"activityId\": \"\",\n  \"serviceUrl\": \"\",\n  \"id\": \"\"\n}")

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

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

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

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

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

}
POST /baseUrl/v3/connectorInternals/conversationResourceResponse HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 54

{
  "activityId": "",
  "serviceUrl": "",
  "id": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/conversationResourceResponse")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"activityId\": \"\",\n  \"serviceUrl\": \"\",\n  \"id\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/conversationResourceResponse"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"activityId\": \"\",\n  \"serviceUrl\": \"\",\n  \"id\": \"\"\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  \"activityId\": \"\",\n  \"serviceUrl\": \"\",\n  \"id\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/conversationResourceResponse")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/conversationResourceResponse")
  .header("content-type", "application/json")
  .body("{\n  \"activityId\": \"\",\n  \"serviceUrl\": \"\",\n  \"id\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  activityId: '',
  serviceUrl: '',
  id: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/conversationResourceResponse');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/conversationResourceResponse',
  headers: {'content-type': 'application/json'},
  data: {activityId: '', serviceUrl: '', id: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/conversationResourceResponse';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"activityId":"","serviceUrl":"","id":""}'
};

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}}/v3/connectorInternals/conversationResourceResponse',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "activityId": "",\n  "serviceUrl": "",\n  "id": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"activityId\": \"\",\n  \"serviceUrl\": \"\",\n  \"id\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/conversationResourceResponse")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/conversationResourceResponse',
  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({activityId: '', serviceUrl: '', id: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/conversationResourceResponse',
  headers: {'content-type': 'application/json'},
  body: {activityId: '', serviceUrl: '', id: ''},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/conversationResourceResponse');

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

req.type('json');
req.send({
  activityId: '',
  serviceUrl: '',
  id: ''
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/conversationResourceResponse',
  headers: {'content-type': 'application/json'},
  data: {activityId: '', serviceUrl: '', id: ''}
};

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

const url = '{{baseUrl}}/v3/connectorInternals/conversationResourceResponse';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"activityId":"","serviceUrl":"","id":""}'
};

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 = @{ @"activityId": @"",
                              @"serviceUrl": @"",
                              @"id": @"" };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/conversationResourceResponse" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"activityId\": \"\",\n  \"serviceUrl\": \"\",\n  \"id\": \"\"\n}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/conversationResourceResponse', [
  'body' => '{
  "activityId": "",
  "serviceUrl": "",
  "id": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/conversationResourceResponse');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'activityId' => '',
  'serviceUrl' => '',
  'id' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'activityId' => '',
  'serviceUrl' => '',
  'id' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/conversationResourceResponse');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/conversationResourceResponse' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "activityId": "",
  "serviceUrl": "",
  "id": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/conversationResourceResponse' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "activityId": "",
  "serviceUrl": "",
  "id": ""
}'
import http.client

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

payload = "{\n  \"activityId\": \"\",\n  \"serviceUrl\": \"\",\n  \"id\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v3/connectorInternals/conversationResourceResponse", payload, headers)

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

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

url = "{{baseUrl}}/v3/connectorInternals/conversationResourceResponse"

payload = {
    "activityId": "",
    "serviceUrl": "",
    "id": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3/connectorInternals/conversationResourceResponse"

payload <- "{\n  \"activityId\": \"\",\n  \"serviceUrl\": \"\",\n  \"id\": \"\"\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v3/connectorInternals/conversationResourceResponse")

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

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

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

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

response = conn.post('/baseUrl/v3/connectorInternals/conversationResourceResponse') do |req|
  req.body = "{\n  \"activityId\": \"\",\n  \"serviceUrl\": \"\",\n  \"id\": \"\"\n}"
end

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

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

    let payload = json!({
        "activityId": "",
        "serviceUrl": "",
        "id": ""
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/conversationResourceResponse \
  --header 'content-type: application/json' \
  --data '{
  "activityId": "",
  "serviceUrl": "",
  "id": ""
}'
echo '{
  "activityId": "",
  "serviceUrl": "",
  "id": ""
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/conversationResourceResponse \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "activityId": "",\n  "serviceUrl": "",\n  "id": ""\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/conversationResourceResponse
import Foundation

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

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

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

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

dataTask.resume()
POST PostConversationsResult
{{baseUrl}}/v3/connectorInternals/conversationsResult
BODY json

{
  "continuationToken": "",
  "conversations": [
    {
      "id": "",
      "members": [
        {
          "id": "",
          "name": "",
          "aadObjectId": "",
          "role": ""
        }
      ]
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/conversationsResult");

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  \"continuationToken\": \"\",\n  \"conversations\": [\n    {\n      \"id\": \"\",\n      \"members\": [\n        {\n          \"id\": \"\",\n          \"name\": \"\",\n          \"aadObjectId\": \"\",\n          \"role\": \"\"\n        }\n      ]\n    }\n  ]\n}");

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

(client/post "{{baseUrl}}/v3/connectorInternals/conversationsResult" {:content-type :json
                                                                                      :form-params {:continuationToken ""
                                                                                                    :conversations [{:id ""
                                                                                                                     :members [{:id ""
                                                                                                                                :name ""
                                                                                                                                :aadObjectId ""
                                                                                                                                :role ""}]}]}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/conversationsResult"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"continuationToken\": \"\",\n  \"conversations\": [\n    {\n      \"id\": \"\",\n      \"members\": [\n        {\n          \"id\": \"\",\n          \"name\": \"\",\n          \"aadObjectId\": \"\",\n          \"role\": \"\"\n        }\n      ]\n    }\n  ]\n}"

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

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

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/conversationsResult"

	payload := strings.NewReader("{\n  \"continuationToken\": \"\",\n  \"conversations\": [\n    {\n      \"id\": \"\",\n      \"members\": [\n        {\n          \"id\": \"\",\n          \"name\": \"\",\n          \"aadObjectId\": \"\",\n          \"role\": \"\"\n        }\n      ]\n    }\n  ]\n}")

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

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

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

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

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

}
POST /baseUrl/v3/connectorInternals/conversationsResult HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 222

{
  "continuationToken": "",
  "conversations": [
    {
      "id": "",
      "members": [
        {
          "id": "",
          "name": "",
          "aadObjectId": "",
          "role": ""
        }
      ]
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/conversationsResult")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"continuationToken\": \"\",\n  \"conversations\": [\n    {\n      \"id\": \"\",\n      \"members\": [\n        {\n          \"id\": \"\",\n          \"name\": \"\",\n          \"aadObjectId\": \"\",\n          \"role\": \"\"\n        }\n      ]\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/conversationsResult"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"continuationToken\": \"\",\n  \"conversations\": [\n    {\n      \"id\": \"\",\n      \"members\": [\n        {\n          \"id\": \"\",\n          \"name\": \"\",\n          \"aadObjectId\": \"\",\n          \"role\": \"\"\n        }\n      ]\n    }\n  ]\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"continuationToken\": \"\",\n  \"conversations\": [\n    {\n      \"id\": \"\",\n      \"members\": [\n        {\n          \"id\": \"\",\n          \"name\": \"\",\n          \"aadObjectId\": \"\",\n          \"role\": \"\"\n        }\n      ]\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/conversationsResult")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/conversationsResult")
  .header("content-type", "application/json")
  .body("{\n  \"continuationToken\": \"\",\n  \"conversations\": [\n    {\n      \"id\": \"\",\n      \"members\": [\n        {\n          \"id\": \"\",\n          \"name\": \"\",\n          \"aadObjectId\": \"\",\n          \"role\": \"\"\n        }\n      ]\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  continuationToken: '',
  conversations: [
    {
      id: '',
      members: [
        {
          id: '',
          name: '',
          aadObjectId: '',
          role: ''
        }
      ]
    }
  ]
});

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

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

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/conversationsResult');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/conversationsResult',
  headers: {'content-type': 'application/json'},
  data: {
    continuationToken: '',
    conversations: [{id: '', members: [{id: '', name: '', aadObjectId: '', role: ''}]}]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/conversationsResult';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"continuationToken":"","conversations":[{"id":"","members":[{"id":"","name":"","aadObjectId":"","role":""}]}]}'
};

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}}/v3/connectorInternals/conversationsResult',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "continuationToken": "",\n  "conversations": [\n    {\n      "id": "",\n      "members": [\n        {\n          "id": "",\n          "name": "",\n          "aadObjectId": "",\n          "role": ""\n        }\n      ]\n    }\n  ]\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"continuationToken\": \"\",\n  \"conversations\": [\n    {\n      \"id\": \"\",\n      \"members\": [\n        {\n          \"id\": \"\",\n          \"name\": \"\",\n          \"aadObjectId\": \"\",\n          \"role\": \"\"\n        }\n      ]\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/conversationsResult")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/conversationsResult',
  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({
  continuationToken: '',
  conversations: [{id: '', members: [{id: '', name: '', aadObjectId: '', role: ''}]}]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/conversationsResult',
  headers: {'content-type': 'application/json'},
  body: {
    continuationToken: '',
    conversations: [{id: '', members: [{id: '', name: '', aadObjectId: '', role: ''}]}]
  },
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/conversationsResult');

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

req.type('json');
req.send({
  continuationToken: '',
  conversations: [
    {
      id: '',
      members: [
        {
          id: '',
          name: '',
          aadObjectId: '',
          role: ''
        }
      ]
    }
  ]
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/conversationsResult',
  headers: {'content-type': 'application/json'},
  data: {
    continuationToken: '',
    conversations: [{id: '', members: [{id: '', name: '', aadObjectId: '', role: ''}]}]
  }
};

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

const url = '{{baseUrl}}/v3/connectorInternals/conversationsResult';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"continuationToken":"","conversations":[{"id":"","members":[{"id":"","name":"","aadObjectId":"","role":""}]}]}'
};

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 = @{ @"continuationToken": @"",
                              @"conversations": @[ @{ @"id": @"", @"members": @[ @{ @"id": @"", @"name": @"", @"aadObjectId": @"", @"role": @"" } ] } ] };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/conversationsResult" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"continuationToken\": \"\",\n  \"conversations\": [\n    {\n      \"id\": \"\",\n      \"members\": [\n        {\n          \"id\": \"\",\n          \"name\": \"\",\n          \"aadObjectId\": \"\",\n          \"role\": \"\"\n        }\n      ]\n    }\n  ]\n}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/conversationsResult', [
  'body' => '{
  "continuationToken": "",
  "conversations": [
    {
      "id": "",
      "members": [
        {
          "id": "",
          "name": "",
          "aadObjectId": "",
          "role": ""
        }
      ]
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/conversationsResult');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'continuationToken' => '',
  'conversations' => [
    [
        'id' => '',
        'members' => [
                [
                                'id' => '',
                                'name' => '',
                                'aadObjectId' => '',
                                'role' => ''
                ]
        ]
    ]
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'continuationToken' => '',
  'conversations' => [
    [
        'id' => '',
        'members' => [
                [
                                'id' => '',
                                'name' => '',
                                'aadObjectId' => '',
                                'role' => ''
                ]
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/conversationsResult');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/conversationsResult' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "continuationToken": "",
  "conversations": [
    {
      "id": "",
      "members": [
        {
          "id": "",
          "name": "",
          "aadObjectId": "",
          "role": ""
        }
      ]
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/conversationsResult' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "continuationToken": "",
  "conversations": [
    {
      "id": "",
      "members": [
        {
          "id": "",
          "name": "",
          "aadObjectId": "",
          "role": ""
        }
      ]
    }
  ]
}'
import http.client

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

payload = "{\n  \"continuationToken\": \"\",\n  \"conversations\": [\n    {\n      \"id\": \"\",\n      \"members\": [\n        {\n          \"id\": \"\",\n          \"name\": \"\",\n          \"aadObjectId\": \"\",\n          \"role\": \"\"\n        }\n      ]\n    }\n  ]\n}"

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

conn.request("POST", "/baseUrl/v3/connectorInternals/conversationsResult", payload, headers)

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

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

url = "{{baseUrl}}/v3/connectorInternals/conversationsResult"

payload = {
    "continuationToken": "",
    "conversations": [
        {
            "id": "",
            "members": [
                {
                    "id": "",
                    "name": "",
                    "aadObjectId": "",
                    "role": ""
                }
            ]
        }
    ]
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3/connectorInternals/conversationsResult"

payload <- "{\n  \"continuationToken\": \"\",\n  \"conversations\": [\n    {\n      \"id\": \"\",\n      \"members\": [\n        {\n          \"id\": \"\",\n          \"name\": \"\",\n          \"aadObjectId\": \"\",\n          \"role\": \"\"\n        }\n      ]\n    }\n  ]\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v3/connectorInternals/conversationsResult")

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

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"continuationToken\": \"\",\n  \"conversations\": [\n    {\n      \"id\": \"\",\n      \"members\": [\n        {\n          \"id\": \"\",\n          \"name\": \"\",\n          \"aadObjectId\": \"\",\n          \"role\": \"\"\n        }\n      ]\n    }\n  ]\n}"

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

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

response = conn.post('/baseUrl/v3/connectorInternals/conversationsResult') do |req|
  req.body = "{\n  \"continuationToken\": \"\",\n  \"conversations\": [\n    {\n      \"id\": \"\",\n      \"members\": [\n        {\n          \"id\": \"\",\n          \"name\": \"\",\n          \"aadObjectId\": \"\",\n          \"role\": \"\"\n        }\n      ]\n    }\n  ]\n}"
end

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

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

    let payload = json!({
        "continuationToken": "",
        "conversations": (
            json!({
                "id": "",
                "members": (
                    json!({
                        "id": "",
                        "name": "",
                        "aadObjectId": "",
                        "role": ""
                    })
                )
            })
        )
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/conversationsResult \
  --header 'content-type: application/json' \
  --data '{
  "continuationToken": "",
  "conversations": [
    {
      "id": "",
      "members": [
        {
          "id": "",
          "name": "",
          "aadObjectId": "",
          "role": ""
        }
      ]
    }
  ]
}'
echo '{
  "continuationToken": "",
  "conversations": [
    {
      "id": "",
      "members": [
        {
          "id": "",
          "name": "",
          "aadObjectId": "",
          "role": ""
        }
      ]
    }
  ]
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/conversationsResult \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "continuationToken": "",\n  "conversations": [\n    {\n      "id": "",\n      "members": [\n        {\n          "id": "",\n          "name": "",\n          "aadObjectId": "",\n          "role": ""\n        }\n      ]\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/conversationsResult
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "continuationToken": "",
  "conversations": [
    [
      "id": "",
      "members": [
        [
          "id": "",
          "name": "",
          "aadObjectId": "",
          "role": ""
        ]
      ]
    ]
  ]
] as [String : Any]

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

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

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

dataTask.resume()
POST PostErrorResponse
{{baseUrl}}/v3/connectorInternals/errorResponse
BODY json

{
  "error": {
    "code": "",
    "message": "",
    "innerHttpError": {
      "statusCode": 0,
      "body": {}
    }
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/errorResponse");

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  \"error\": {\n    \"code\": \"\",\n    \"message\": \"\",\n    \"innerHttpError\": {\n      \"statusCode\": 0,\n      \"body\": {}\n    }\n  }\n}");

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

(client/post "{{baseUrl}}/v3/connectorInternals/errorResponse" {:content-type :json
                                                                                :form-params {:error {:code ""
                                                                                                      :message ""
                                                                                                      :innerHttpError {:statusCode 0
                                                                                                                       :body {}}}}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/errorResponse"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"error\": {\n    \"code\": \"\",\n    \"message\": \"\",\n    \"innerHttpError\": {\n      \"statusCode\": 0,\n      \"body\": {}\n    }\n  }\n}"

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

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

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/errorResponse"

	payload := strings.NewReader("{\n  \"error\": {\n    \"code\": \"\",\n    \"message\": \"\",\n    \"innerHttpError\": {\n      \"statusCode\": 0,\n      \"body\": {}\n    }\n  }\n}")

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

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

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

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

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

}
POST /baseUrl/v3/connectorInternals/errorResponse HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 125

{
  "error": {
    "code": "",
    "message": "",
    "innerHttpError": {
      "statusCode": 0,
      "body": {}
    }
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/errorResponse")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"error\": {\n    \"code\": \"\",\n    \"message\": \"\",\n    \"innerHttpError\": {\n      \"statusCode\": 0,\n      \"body\": {}\n    }\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/errorResponse"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"error\": {\n    \"code\": \"\",\n    \"message\": \"\",\n    \"innerHttpError\": {\n      \"statusCode\": 0,\n      \"body\": {}\n    }\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"error\": {\n    \"code\": \"\",\n    \"message\": \"\",\n    \"innerHttpError\": {\n      \"statusCode\": 0,\n      \"body\": {}\n    }\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/errorResponse")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/errorResponse")
  .header("content-type", "application/json")
  .body("{\n  \"error\": {\n    \"code\": \"\",\n    \"message\": \"\",\n    \"innerHttpError\": {\n      \"statusCode\": 0,\n      \"body\": {}\n    }\n  }\n}")
  .asString();
const data = JSON.stringify({
  error: {
    code: '',
    message: '',
    innerHttpError: {
      statusCode: 0,
      body: {}
    }
  }
});

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

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

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/errorResponse');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/errorResponse',
  headers: {'content-type': 'application/json'},
  data: {error: {code: '', message: '', innerHttpError: {statusCode: 0, body: {}}}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/errorResponse';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"error":{"code":"","message":"","innerHttpError":{"statusCode":0,"body":{}}}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v3/connectorInternals/errorResponse',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "error": {\n    "code": "",\n    "message": "",\n    "innerHttpError": {\n      "statusCode": 0,\n      "body": {}\n    }\n  }\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"error\": {\n    \"code\": \"\",\n    \"message\": \"\",\n    \"innerHttpError\": {\n      \"statusCode\": 0,\n      \"body\": {}\n    }\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/errorResponse")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/errorResponse',
  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({error: {code: '', message: '', innerHttpError: {statusCode: 0, body: {}}}}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/errorResponse',
  headers: {'content-type': 'application/json'},
  body: {error: {code: '', message: '', innerHttpError: {statusCode: 0, body: {}}}},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/errorResponse');

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

req.type('json');
req.send({
  error: {
    code: '',
    message: '',
    innerHttpError: {
      statusCode: 0,
      body: {}
    }
  }
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/errorResponse',
  headers: {'content-type': 'application/json'},
  data: {error: {code: '', message: '', innerHttpError: {statusCode: 0, body: {}}}}
};

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

const url = '{{baseUrl}}/v3/connectorInternals/errorResponse';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"error":{"code":"","message":"","innerHttpError":{"statusCode":0,"body":{}}}}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"error": @{ @"code": @"", @"message": @"", @"innerHttpError": @{ @"statusCode": @0, @"body": @{  } } } };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/errorResponse" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"error\": {\n    \"code\": \"\",\n    \"message\": \"\",\n    \"innerHttpError\": {\n      \"statusCode\": 0,\n      \"body\": {}\n    }\n  }\n}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/errorResponse', [
  'body' => '{
  "error": {
    "code": "",
    "message": "",
    "innerHttpError": {
      "statusCode": 0,
      "body": {}
    }
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/errorResponse');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'error' => [
    'code' => '',
    'message' => '',
    'innerHttpError' => [
        'statusCode' => 0,
        'body' => [
                
        ]
    ]
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'error' => [
    'code' => '',
    'message' => '',
    'innerHttpError' => [
        'statusCode' => 0,
        'body' => [
                
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/errorResponse');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/errorResponse' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "error": {
    "code": "",
    "message": "",
    "innerHttpError": {
      "statusCode": 0,
      "body": {}
    }
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/errorResponse' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "error": {
    "code": "",
    "message": "",
    "innerHttpError": {
      "statusCode": 0,
      "body": {}
    }
  }
}'
import http.client

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

payload = "{\n  \"error\": {\n    \"code\": \"\",\n    \"message\": \"\",\n    \"innerHttpError\": {\n      \"statusCode\": 0,\n      \"body\": {}\n    }\n  }\n}"

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

conn.request("POST", "/baseUrl/v3/connectorInternals/errorResponse", payload, headers)

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

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

url = "{{baseUrl}}/v3/connectorInternals/errorResponse"

payload = { "error": {
        "code": "",
        "message": "",
        "innerHttpError": {
            "statusCode": 0,
            "body": {}
        }
    } }
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3/connectorInternals/errorResponse"

payload <- "{\n  \"error\": {\n    \"code\": \"\",\n    \"message\": \"\",\n    \"innerHttpError\": {\n      \"statusCode\": 0,\n      \"body\": {}\n    }\n  }\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v3/connectorInternals/errorResponse")

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

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"error\": {\n    \"code\": \"\",\n    \"message\": \"\",\n    \"innerHttpError\": {\n      \"statusCode\": 0,\n      \"body\": {}\n    }\n  }\n}"

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

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

response = conn.post('/baseUrl/v3/connectorInternals/errorResponse') do |req|
  req.body = "{\n  \"error\": {\n    \"code\": \"\",\n    \"message\": \"\",\n    \"innerHttpError\": {\n      \"statusCode\": 0,\n      \"body\": {}\n    }\n  }\n}"
end

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

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

    let payload = json!({"error": json!({
            "code": "",
            "message": "",
            "innerHttpError": json!({
                "statusCode": 0,
                "body": json!({})
            })
        })});

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/errorResponse \
  --header 'content-type: application/json' \
  --data '{
  "error": {
    "code": "",
    "message": "",
    "innerHttpError": {
      "statusCode": 0,
      "body": {}
    }
  }
}'
echo '{
  "error": {
    "code": "",
    "message": "",
    "innerHttpError": {
      "statusCode": 0,
      "body": {}
    }
  }
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/errorResponse \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "error": {\n    "code": "",\n    "message": "",\n    "innerHttpError": {\n      "statusCode": 0,\n      "body": {}\n    }\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/errorResponse
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["error": [
    "code": "",
    "message": "",
    "innerHttpError": [
      "statusCode": 0,
      "body": []
    ]
  ]] as [String : Any]

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

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

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

dataTask.resume()
POST PostExpectedReplies
{{baseUrl}}/v3/connectorInternals/expectedReplies
BODY json

{
  "activities": [
    {
      "type": "",
      "id": "",
      "timestamp": "",
      "localTimestamp": "",
      "localTimezone": "",
      "callerId": "",
      "serviceUrl": "",
      "channelId": "",
      "from": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "conversation": {
        "isGroup": false,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "recipient": {},
      "textFormat": "",
      "attachmentLayout": "",
      "membersAdded": [
        {}
      ],
      "membersRemoved": [
        {}
      ],
      "reactionsAdded": [
        {
          "type": ""
        }
      ],
      "reactionsRemoved": [
        {}
      ],
      "topicName": "",
      "historyDisclosed": false,
      "locale": "",
      "text": "",
      "speak": "",
      "inputHint": "",
      "summary": "",
      "suggestedActions": {
        "to": [],
        "actions": [
          {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
          }
        ]
      },
      "attachments": [
        {
          "contentType": "",
          "contentUrl": "",
          "content": {},
          "name": "",
          "thumbnailUrl": ""
        }
      ],
      "entities": [
        {
          "type": ""
        }
      ],
      "channelData": {},
      "action": "",
      "replyToId": "",
      "label": "",
      "valueType": "",
      "value": {},
      "name": "",
      "relatesTo": {
        "activityId": "",
        "user": {},
        "bot": {},
        "conversation": {},
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
      },
      "code": "",
      "expiration": "",
      "importance": "",
      "deliveryMode": "",
      "listenFor": [],
      "textHighlights": [
        {
          "text": "",
          "occurrence": 0
        }
      ],
      "semanticAction": {
        "state": "",
        "id": "",
        "entities": {}
      }
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/expectedReplies");

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  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}");

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

(client/post "{{baseUrl}}/v3/connectorInternals/expectedReplies" {:content-type :json
                                                                                  :form-params {:activities [{:type ""
                                                                                                              :id ""
                                                                                                              :timestamp ""
                                                                                                              :localTimestamp ""
                                                                                                              :localTimezone ""
                                                                                                              :callerId ""
                                                                                                              :serviceUrl ""
                                                                                                              :channelId ""
                                                                                                              :from {:id ""
                                                                                                                     :name ""
                                                                                                                     :aadObjectId ""
                                                                                                                     :role ""}
                                                                                                              :conversation {:isGroup false
                                                                                                                             :conversationType ""
                                                                                                                             :tenantId ""
                                                                                                                             :id ""
                                                                                                                             :name ""
                                                                                                                             :aadObjectId ""
                                                                                                                             :role ""}
                                                                                                              :recipient {}
                                                                                                              :textFormat ""
                                                                                                              :attachmentLayout ""
                                                                                                              :membersAdded [{}]
                                                                                                              :membersRemoved [{}]
                                                                                                              :reactionsAdded [{:type ""}]
                                                                                                              :reactionsRemoved [{}]
                                                                                                              :topicName ""
                                                                                                              :historyDisclosed false
                                                                                                              :locale ""
                                                                                                              :text ""
                                                                                                              :speak ""
                                                                                                              :inputHint ""
                                                                                                              :summary ""
                                                                                                              :suggestedActions {:to []
                                                                                                                                 :actions [{:type ""
                                                                                                                                            :title ""
                                                                                                                                            :image ""
                                                                                                                                            :imageAltText ""
                                                                                                                                            :text ""
                                                                                                                                            :displayText ""
                                                                                                                                            :value {}
                                                                                                                                            :channelData {}}]}
                                                                                                              :attachments [{:contentType ""
                                                                                                                             :contentUrl ""
                                                                                                                             :content {}
                                                                                                                             :name ""
                                                                                                                             :thumbnailUrl ""}]
                                                                                                              :entities [{:type ""}]
                                                                                                              :channelData {}
                                                                                                              :action ""
                                                                                                              :replyToId ""
                                                                                                              :label ""
                                                                                                              :valueType ""
                                                                                                              :value {}
                                                                                                              :name ""
                                                                                                              :relatesTo {:activityId ""
                                                                                                                          :user {}
                                                                                                                          :bot {}
                                                                                                                          :conversation {}
                                                                                                                          :channelId ""
                                                                                                                          :serviceUrl ""
                                                                                                                          :locale ""}
                                                                                                              :code ""
                                                                                                              :expiration ""
                                                                                                              :importance ""
                                                                                                              :deliveryMode ""
                                                                                                              :listenFor []
                                                                                                              :textHighlights [{:text ""
                                                                                                                                :occurrence 0}]
                                                                                                              :semanticAction {:state ""
                                                                                                                               :id ""
                                                                                                                               :entities {}}}]}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/expectedReplies"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/expectedReplies"),
    Content = new StringContent("{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3/connectorInternals/expectedReplies");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/expectedReplies"

	payload := strings.NewReader("{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}")

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

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

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

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

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

}
POST /baseUrl/v3/connectorInternals/expectedReplies HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2211

{
  "activities": [
    {
      "type": "",
      "id": "",
      "timestamp": "",
      "localTimestamp": "",
      "localTimezone": "",
      "callerId": "",
      "serviceUrl": "",
      "channelId": "",
      "from": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "conversation": {
        "isGroup": false,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "recipient": {},
      "textFormat": "",
      "attachmentLayout": "",
      "membersAdded": [
        {}
      ],
      "membersRemoved": [
        {}
      ],
      "reactionsAdded": [
        {
          "type": ""
        }
      ],
      "reactionsRemoved": [
        {}
      ],
      "topicName": "",
      "historyDisclosed": false,
      "locale": "",
      "text": "",
      "speak": "",
      "inputHint": "",
      "summary": "",
      "suggestedActions": {
        "to": [],
        "actions": [
          {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
          }
        ]
      },
      "attachments": [
        {
          "contentType": "",
          "contentUrl": "",
          "content": {},
          "name": "",
          "thumbnailUrl": ""
        }
      ],
      "entities": [
        {
          "type": ""
        }
      ],
      "channelData": {},
      "action": "",
      "replyToId": "",
      "label": "",
      "valueType": "",
      "value": {},
      "name": "",
      "relatesTo": {
        "activityId": "",
        "user": {},
        "bot": {},
        "conversation": {},
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
      },
      "code": "",
      "expiration": "",
      "importance": "",
      "deliveryMode": "",
      "listenFor": [],
      "textHighlights": [
        {
          "text": "",
          "occurrence": 0
        }
      ],
      "semanticAction": {
        "state": "",
        "id": "",
        "entities": {}
      }
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/expectedReplies")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/expectedReplies"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/expectedReplies")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/expectedReplies")
  .header("content-type", "application/json")
  .body("{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  activities: [
    {
      type: '',
      id: '',
      timestamp: '',
      localTimestamp: '',
      localTimezone: '',
      callerId: '',
      serviceUrl: '',
      channelId: '',
      from: {
        id: '',
        name: '',
        aadObjectId: '',
        role: ''
      },
      conversation: {
        isGroup: false,
        conversationType: '',
        tenantId: '',
        id: '',
        name: '',
        aadObjectId: '',
        role: ''
      },
      recipient: {},
      textFormat: '',
      attachmentLayout: '',
      membersAdded: [
        {}
      ],
      membersRemoved: [
        {}
      ],
      reactionsAdded: [
        {
          type: ''
        }
      ],
      reactionsRemoved: [
        {}
      ],
      topicName: '',
      historyDisclosed: false,
      locale: '',
      text: '',
      speak: '',
      inputHint: '',
      summary: '',
      suggestedActions: {
        to: [],
        actions: [
          {
            type: '',
            title: '',
            image: '',
            imageAltText: '',
            text: '',
            displayText: '',
            value: {},
            channelData: {}
          }
        ]
      },
      attachments: [
        {
          contentType: '',
          contentUrl: '',
          content: {},
          name: '',
          thumbnailUrl: ''
        }
      ],
      entities: [
        {
          type: ''
        }
      ],
      channelData: {},
      action: '',
      replyToId: '',
      label: '',
      valueType: '',
      value: {},
      name: '',
      relatesTo: {
        activityId: '',
        user: {},
        bot: {},
        conversation: {},
        channelId: '',
        serviceUrl: '',
        locale: ''
      },
      code: '',
      expiration: '',
      importance: '',
      deliveryMode: '',
      listenFor: [],
      textHighlights: [
        {
          text: '',
          occurrence: 0
        }
      ],
      semanticAction: {
        state: '',
        id: '',
        entities: {}
      }
    }
  ]
});

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

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

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/expectedReplies');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/expectedReplies',
  headers: {'content-type': 'application/json'},
  data: {
    activities: [
      {
        type: '',
        id: '',
        timestamp: '',
        localTimestamp: '',
        localTimezone: '',
        callerId: '',
        serviceUrl: '',
        channelId: '',
        from: {id: '', name: '', aadObjectId: '', role: ''},
        conversation: {
          isGroup: false,
          conversationType: '',
          tenantId: '',
          id: '',
          name: '',
          aadObjectId: '',
          role: ''
        },
        recipient: {},
        textFormat: '',
        attachmentLayout: '',
        membersAdded: [{}],
        membersRemoved: [{}],
        reactionsAdded: [{type: ''}],
        reactionsRemoved: [{}],
        topicName: '',
        historyDisclosed: false,
        locale: '',
        text: '',
        speak: '',
        inputHint: '',
        summary: '',
        suggestedActions: {
          to: [],
          actions: [
            {
              type: '',
              title: '',
              image: '',
              imageAltText: '',
              text: '',
              displayText: '',
              value: {},
              channelData: {}
            }
          ]
        },
        attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
        entities: [{type: ''}],
        channelData: {},
        action: '',
        replyToId: '',
        label: '',
        valueType: '',
        value: {},
        name: '',
        relatesTo: {
          activityId: '',
          user: {},
          bot: {},
          conversation: {},
          channelId: '',
          serviceUrl: '',
          locale: ''
        },
        code: '',
        expiration: '',
        importance: '',
        deliveryMode: '',
        listenFor: [],
        textHighlights: [{text: '', occurrence: 0}],
        semanticAction: {state: '', id: '', entities: {}}
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/expectedReplies';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"activities":[{"type":"","id":"","timestamp":"","localTimestamp":"","localTimezone":"","callerId":"","serviceUrl":"","channelId":"","from":{"id":"","name":"","aadObjectId":"","role":""},"conversation":{"isGroup":false,"conversationType":"","tenantId":"","id":"","name":"","aadObjectId":"","role":""},"recipient":{},"textFormat":"","attachmentLayout":"","membersAdded":[{}],"membersRemoved":[{}],"reactionsAdded":[{"type":""}],"reactionsRemoved":[{}],"topicName":"","historyDisclosed":false,"locale":"","text":"","speak":"","inputHint":"","summary":"","suggestedActions":{"to":[],"actions":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}]},"attachments":[{"contentType":"","contentUrl":"","content":{},"name":"","thumbnailUrl":""}],"entities":[{"type":""}],"channelData":{},"action":"","replyToId":"","label":"","valueType":"","value":{},"name":"","relatesTo":{"activityId":"","user":{},"bot":{},"conversation":{},"channelId":"","serviceUrl":"","locale":""},"code":"","expiration":"","importance":"","deliveryMode":"","listenFor":[],"textHighlights":[{"text":"","occurrence":0}],"semanticAction":{"state":"","id":"","entities":{}}}]}'
};

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}}/v3/connectorInternals/expectedReplies',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "activities": [\n    {\n      "type": "",\n      "id": "",\n      "timestamp": "",\n      "localTimestamp": "",\n      "localTimezone": "",\n      "callerId": "",\n      "serviceUrl": "",\n      "channelId": "",\n      "from": {\n        "id": "",\n        "name": "",\n        "aadObjectId": "",\n        "role": ""\n      },\n      "conversation": {\n        "isGroup": false,\n        "conversationType": "",\n        "tenantId": "",\n        "id": "",\n        "name": "",\n        "aadObjectId": "",\n        "role": ""\n      },\n      "recipient": {},\n      "textFormat": "",\n      "attachmentLayout": "",\n      "membersAdded": [\n        {}\n      ],\n      "membersRemoved": [\n        {}\n      ],\n      "reactionsAdded": [\n        {\n          "type": ""\n        }\n      ],\n      "reactionsRemoved": [\n        {}\n      ],\n      "topicName": "",\n      "historyDisclosed": false,\n      "locale": "",\n      "text": "",\n      "speak": "",\n      "inputHint": "",\n      "summary": "",\n      "suggestedActions": {\n        "to": [],\n        "actions": [\n          {\n            "type": "",\n            "title": "",\n            "image": "",\n            "imageAltText": "",\n            "text": "",\n            "displayText": "",\n            "value": {},\n            "channelData": {}\n          }\n        ]\n      },\n      "attachments": [\n        {\n          "contentType": "",\n          "contentUrl": "",\n          "content": {},\n          "name": "",\n          "thumbnailUrl": ""\n        }\n      ],\n      "entities": [\n        {\n          "type": ""\n        }\n      ],\n      "channelData": {},\n      "action": "",\n      "replyToId": "",\n      "label": "",\n      "valueType": "",\n      "value": {},\n      "name": "",\n      "relatesTo": {\n        "activityId": "",\n        "user": {},\n        "bot": {},\n        "conversation": {},\n        "channelId": "",\n        "serviceUrl": "",\n        "locale": ""\n      },\n      "code": "",\n      "expiration": "",\n      "importance": "",\n      "deliveryMode": "",\n      "listenFor": [],\n      "textHighlights": [\n        {\n          "text": "",\n          "occurrence": 0\n        }\n      ],\n      "semanticAction": {\n        "state": "",\n        "id": "",\n        "entities": {}\n      }\n    }\n  ]\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/expectedReplies")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/expectedReplies',
  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({
  activities: [
    {
      type: '',
      id: '',
      timestamp: '',
      localTimestamp: '',
      localTimezone: '',
      callerId: '',
      serviceUrl: '',
      channelId: '',
      from: {id: '', name: '', aadObjectId: '', role: ''},
      conversation: {
        isGroup: false,
        conversationType: '',
        tenantId: '',
        id: '',
        name: '',
        aadObjectId: '',
        role: ''
      },
      recipient: {},
      textFormat: '',
      attachmentLayout: '',
      membersAdded: [{}],
      membersRemoved: [{}],
      reactionsAdded: [{type: ''}],
      reactionsRemoved: [{}],
      topicName: '',
      historyDisclosed: false,
      locale: '',
      text: '',
      speak: '',
      inputHint: '',
      summary: '',
      suggestedActions: {
        to: [],
        actions: [
          {
            type: '',
            title: '',
            image: '',
            imageAltText: '',
            text: '',
            displayText: '',
            value: {},
            channelData: {}
          }
        ]
      },
      attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
      entities: [{type: ''}],
      channelData: {},
      action: '',
      replyToId: '',
      label: '',
      valueType: '',
      value: {},
      name: '',
      relatesTo: {
        activityId: '',
        user: {},
        bot: {},
        conversation: {},
        channelId: '',
        serviceUrl: '',
        locale: ''
      },
      code: '',
      expiration: '',
      importance: '',
      deliveryMode: '',
      listenFor: [],
      textHighlights: [{text: '', occurrence: 0}],
      semanticAction: {state: '', id: '', entities: {}}
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/expectedReplies',
  headers: {'content-type': 'application/json'},
  body: {
    activities: [
      {
        type: '',
        id: '',
        timestamp: '',
        localTimestamp: '',
        localTimezone: '',
        callerId: '',
        serviceUrl: '',
        channelId: '',
        from: {id: '', name: '', aadObjectId: '', role: ''},
        conversation: {
          isGroup: false,
          conversationType: '',
          tenantId: '',
          id: '',
          name: '',
          aadObjectId: '',
          role: ''
        },
        recipient: {},
        textFormat: '',
        attachmentLayout: '',
        membersAdded: [{}],
        membersRemoved: [{}],
        reactionsAdded: [{type: ''}],
        reactionsRemoved: [{}],
        topicName: '',
        historyDisclosed: false,
        locale: '',
        text: '',
        speak: '',
        inputHint: '',
        summary: '',
        suggestedActions: {
          to: [],
          actions: [
            {
              type: '',
              title: '',
              image: '',
              imageAltText: '',
              text: '',
              displayText: '',
              value: {},
              channelData: {}
            }
          ]
        },
        attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
        entities: [{type: ''}],
        channelData: {},
        action: '',
        replyToId: '',
        label: '',
        valueType: '',
        value: {},
        name: '',
        relatesTo: {
          activityId: '',
          user: {},
          bot: {},
          conversation: {},
          channelId: '',
          serviceUrl: '',
          locale: ''
        },
        code: '',
        expiration: '',
        importance: '',
        deliveryMode: '',
        listenFor: [],
        textHighlights: [{text: '', occurrence: 0}],
        semanticAction: {state: '', id: '', entities: {}}
      }
    ]
  },
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/expectedReplies');

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

req.type('json');
req.send({
  activities: [
    {
      type: '',
      id: '',
      timestamp: '',
      localTimestamp: '',
      localTimezone: '',
      callerId: '',
      serviceUrl: '',
      channelId: '',
      from: {
        id: '',
        name: '',
        aadObjectId: '',
        role: ''
      },
      conversation: {
        isGroup: false,
        conversationType: '',
        tenantId: '',
        id: '',
        name: '',
        aadObjectId: '',
        role: ''
      },
      recipient: {},
      textFormat: '',
      attachmentLayout: '',
      membersAdded: [
        {}
      ],
      membersRemoved: [
        {}
      ],
      reactionsAdded: [
        {
          type: ''
        }
      ],
      reactionsRemoved: [
        {}
      ],
      topicName: '',
      historyDisclosed: false,
      locale: '',
      text: '',
      speak: '',
      inputHint: '',
      summary: '',
      suggestedActions: {
        to: [],
        actions: [
          {
            type: '',
            title: '',
            image: '',
            imageAltText: '',
            text: '',
            displayText: '',
            value: {},
            channelData: {}
          }
        ]
      },
      attachments: [
        {
          contentType: '',
          contentUrl: '',
          content: {},
          name: '',
          thumbnailUrl: ''
        }
      ],
      entities: [
        {
          type: ''
        }
      ],
      channelData: {},
      action: '',
      replyToId: '',
      label: '',
      valueType: '',
      value: {},
      name: '',
      relatesTo: {
        activityId: '',
        user: {},
        bot: {},
        conversation: {},
        channelId: '',
        serviceUrl: '',
        locale: ''
      },
      code: '',
      expiration: '',
      importance: '',
      deliveryMode: '',
      listenFor: [],
      textHighlights: [
        {
          text: '',
          occurrence: 0
        }
      ],
      semanticAction: {
        state: '',
        id: '',
        entities: {}
      }
    }
  ]
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/expectedReplies',
  headers: {'content-type': 'application/json'},
  data: {
    activities: [
      {
        type: '',
        id: '',
        timestamp: '',
        localTimestamp: '',
        localTimezone: '',
        callerId: '',
        serviceUrl: '',
        channelId: '',
        from: {id: '', name: '', aadObjectId: '', role: ''},
        conversation: {
          isGroup: false,
          conversationType: '',
          tenantId: '',
          id: '',
          name: '',
          aadObjectId: '',
          role: ''
        },
        recipient: {},
        textFormat: '',
        attachmentLayout: '',
        membersAdded: [{}],
        membersRemoved: [{}],
        reactionsAdded: [{type: ''}],
        reactionsRemoved: [{}],
        topicName: '',
        historyDisclosed: false,
        locale: '',
        text: '',
        speak: '',
        inputHint: '',
        summary: '',
        suggestedActions: {
          to: [],
          actions: [
            {
              type: '',
              title: '',
              image: '',
              imageAltText: '',
              text: '',
              displayText: '',
              value: {},
              channelData: {}
            }
          ]
        },
        attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
        entities: [{type: ''}],
        channelData: {},
        action: '',
        replyToId: '',
        label: '',
        valueType: '',
        value: {},
        name: '',
        relatesTo: {
          activityId: '',
          user: {},
          bot: {},
          conversation: {},
          channelId: '',
          serviceUrl: '',
          locale: ''
        },
        code: '',
        expiration: '',
        importance: '',
        deliveryMode: '',
        listenFor: [],
        textHighlights: [{text: '', occurrence: 0}],
        semanticAction: {state: '', id: '', entities: {}}
      }
    ]
  }
};

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

const url = '{{baseUrl}}/v3/connectorInternals/expectedReplies';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"activities":[{"type":"","id":"","timestamp":"","localTimestamp":"","localTimezone":"","callerId":"","serviceUrl":"","channelId":"","from":{"id":"","name":"","aadObjectId":"","role":""},"conversation":{"isGroup":false,"conversationType":"","tenantId":"","id":"","name":"","aadObjectId":"","role":""},"recipient":{},"textFormat":"","attachmentLayout":"","membersAdded":[{}],"membersRemoved":[{}],"reactionsAdded":[{"type":""}],"reactionsRemoved":[{}],"topicName":"","historyDisclosed":false,"locale":"","text":"","speak":"","inputHint":"","summary":"","suggestedActions":{"to":[],"actions":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}]},"attachments":[{"contentType":"","contentUrl":"","content":{},"name":"","thumbnailUrl":""}],"entities":[{"type":""}],"channelData":{},"action":"","replyToId":"","label":"","valueType":"","value":{},"name":"","relatesTo":{"activityId":"","user":{},"bot":{},"conversation":{},"channelId":"","serviceUrl":"","locale":""},"code":"","expiration":"","importance":"","deliveryMode":"","listenFor":[],"textHighlights":[{"text":"","occurrence":0}],"semanticAction":{"state":"","id":"","entities":{}}}]}'
};

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 = @{ @"activities": @[ @{ @"type": @"", @"id": @"", @"timestamp": @"", @"localTimestamp": @"", @"localTimezone": @"", @"callerId": @"", @"serviceUrl": @"", @"channelId": @"", @"from": @{ @"id": @"", @"name": @"", @"aadObjectId": @"", @"role": @"" }, @"conversation": @{ @"isGroup": @NO, @"conversationType": @"", @"tenantId": @"", @"id": @"", @"name": @"", @"aadObjectId": @"", @"role": @"" }, @"recipient": @{  }, @"textFormat": @"", @"attachmentLayout": @"", @"membersAdded": @[ @{  } ], @"membersRemoved": @[ @{  } ], @"reactionsAdded": @[ @{ @"type": @"" } ], @"reactionsRemoved": @[ @{  } ], @"topicName": @"", @"historyDisclosed": @NO, @"locale": @"", @"text": @"", @"speak": @"", @"inputHint": @"", @"summary": @"", @"suggestedActions": @{ @"to": @[  ], @"actions": @[ @{ @"type": @"", @"title": @"", @"image": @"", @"imageAltText": @"", @"text": @"", @"displayText": @"", @"value": @{  }, @"channelData": @{  } } ] }, @"attachments": @[ @{ @"contentType": @"", @"contentUrl": @"", @"content": @{  }, @"name": @"", @"thumbnailUrl": @"" } ], @"entities": @[ @{ @"type": @"" } ], @"channelData": @{  }, @"action": @"", @"replyToId": @"", @"label": @"", @"valueType": @"", @"value": @{  }, @"name": @"", @"relatesTo": @{ @"activityId": @"", @"user": @{  }, @"bot": @{  }, @"conversation": @{  }, @"channelId": @"", @"serviceUrl": @"", @"locale": @"" }, @"code": @"", @"expiration": @"", @"importance": @"", @"deliveryMode": @"", @"listenFor": @[  ], @"textHighlights": @[ @{ @"text": @"", @"occurrence": @0 } ], @"semanticAction": @{ @"state": @"", @"id": @"", @"entities": @{  } } } ] };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/expectedReplies" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/expectedReplies",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'activities' => [
        [
                'type' => '',
                'id' => '',
                'timestamp' => '',
                'localTimestamp' => '',
                'localTimezone' => '',
                'callerId' => '',
                'serviceUrl' => '',
                'channelId' => '',
                'from' => [
                                'id' => '',
                                'name' => '',
                                'aadObjectId' => '',
                                'role' => ''
                ],
                'conversation' => [
                                'isGroup' => null,
                                'conversationType' => '',
                                'tenantId' => '',
                                'id' => '',
                                'name' => '',
                                'aadObjectId' => '',
                                'role' => ''
                ],
                'recipient' => [
                                
                ],
                'textFormat' => '',
                'attachmentLayout' => '',
                'membersAdded' => [
                                [
                                                                
                                ]
                ],
                'membersRemoved' => [
                                [
                                                                
                                ]
                ],
                'reactionsAdded' => [
                                [
                                                                'type' => ''
                                ]
                ],
                'reactionsRemoved' => [
                                [
                                                                
                                ]
                ],
                'topicName' => '',
                'historyDisclosed' => null,
                'locale' => '',
                'text' => '',
                'speak' => '',
                'inputHint' => '',
                'summary' => '',
                'suggestedActions' => [
                                'to' => [
                                                                
                                ],
                                'actions' => [
                                                                [
                                                                                                                                'type' => '',
                                                                                                                                'title' => '',
                                                                                                                                'image' => '',
                                                                                                                                'imageAltText' => '',
                                                                                                                                'text' => '',
                                                                                                                                'displayText' => '',
                                                                                                                                'value' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'channelData' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'attachments' => [
                                [
                                                                'contentType' => '',
                                                                'contentUrl' => '',
                                                                'content' => [
                                                                                                                                
                                                                ],
                                                                'name' => '',
                                                                'thumbnailUrl' => ''
                                ]
                ],
                'entities' => [
                                [
                                                                'type' => ''
                                ]
                ],
                'channelData' => [
                                
                ],
                'action' => '',
                'replyToId' => '',
                'label' => '',
                'valueType' => '',
                'value' => [
                                
                ],
                'name' => '',
                'relatesTo' => [
                                'activityId' => '',
                                'user' => [
                                                                
                                ],
                                'bot' => [
                                                                
                                ],
                                'conversation' => [
                                                                
                                ],
                                'channelId' => '',
                                'serviceUrl' => '',
                                'locale' => ''
                ],
                'code' => '',
                'expiration' => '',
                'importance' => '',
                'deliveryMode' => '',
                'listenFor' => [
                                
                ],
                'textHighlights' => [
                                [
                                                                'text' => '',
                                                                'occurrence' => 0
                                ]
                ],
                'semanticAction' => [
                                'state' => '',
                                'id' => '',
                                'entities' => [
                                                                
                                ]
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/expectedReplies', [
  'body' => '{
  "activities": [
    {
      "type": "",
      "id": "",
      "timestamp": "",
      "localTimestamp": "",
      "localTimezone": "",
      "callerId": "",
      "serviceUrl": "",
      "channelId": "",
      "from": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "conversation": {
        "isGroup": false,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "recipient": {},
      "textFormat": "",
      "attachmentLayout": "",
      "membersAdded": [
        {}
      ],
      "membersRemoved": [
        {}
      ],
      "reactionsAdded": [
        {
          "type": ""
        }
      ],
      "reactionsRemoved": [
        {}
      ],
      "topicName": "",
      "historyDisclosed": false,
      "locale": "",
      "text": "",
      "speak": "",
      "inputHint": "",
      "summary": "",
      "suggestedActions": {
        "to": [],
        "actions": [
          {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
          }
        ]
      },
      "attachments": [
        {
          "contentType": "",
          "contentUrl": "",
          "content": {},
          "name": "",
          "thumbnailUrl": ""
        }
      ],
      "entities": [
        {
          "type": ""
        }
      ],
      "channelData": {},
      "action": "",
      "replyToId": "",
      "label": "",
      "valueType": "",
      "value": {},
      "name": "",
      "relatesTo": {
        "activityId": "",
        "user": {},
        "bot": {},
        "conversation": {},
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
      },
      "code": "",
      "expiration": "",
      "importance": "",
      "deliveryMode": "",
      "listenFor": [],
      "textHighlights": [
        {
          "text": "",
          "occurrence": 0
        }
      ],
      "semanticAction": {
        "state": "",
        "id": "",
        "entities": {}
      }
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/expectedReplies');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'activities' => [
    [
        'type' => '',
        'id' => '',
        'timestamp' => '',
        'localTimestamp' => '',
        'localTimezone' => '',
        'callerId' => '',
        'serviceUrl' => '',
        'channelId' => '',
        'from' => [
                'id' => '',
                'name' => '',
                'aadObjectId' => '',
                'role' => ''
        ],
        'conversation' => [
                'isGroup' => null,
                'conversationType' => '',
                'tenantId' => '',
                'id' => '',
                'name' => '',
                'aadObjectId' => '',
                'role' => ''
        ],
        'recipient' => [
                
        ],
        'textFormat' => '',
        'attachmentLayout' => '',
        'membersAdded' => [
                [
                                
                ]
        ],
        'membersRemoved' => [
                [
                                
                ]
        ],
        'reactionsAdded' => [
                [
                                'type' => ''
                ]
        ],
        'reactionsRemoved' => [
                [
                                
                ]
        ],
        'topicName' => '',
        'historyDisclosed' => null,
        'locale' => '',
        'text' => '',
        'speak' => '',
        'inputHint' => '',
        'summary' => '',
        'suggestedActions' => [
                'to' => [
                                
                ],
                'actions' => [
                                [
                                                                'type' => '',
                                                                'title' => '',
                                                                'image' => '',
                                                                'imageAltText' => '',
                                                                'text' => '',
                                                                'displayText' => '',
                                                                'value' => [
                                                                                                                                
                                                                ],
                                                                'channelData' => [
                                                                                                                                
                                                                ]
                                ]
                ]
        ],
        'attachments' => [
                [
                                'contentType' => '',
                                'contentUrl' => '',
                                'content' => [
                                                                
                                ],
                                'name' => '',
                                'thumbnailUrl' => ''
                ]
        ],
        'entities' => [
                [
                                'type' => ''
                ]
        ],
        'channelData' => [
                
        ],
        'action' => '',
        'replyToId' => '',
        'label' => '',
        'valueType' => '',
        'value' => [
                
        ],
        'name' => '',
        'relatesTo' => [
                'activityId' => '',
                'user' => [
                                
                ],
                'bot' => [
                                
                ],
                'conversation' => [
                                
                ],
                'channelId' => '',
                'serviceUrl' => '',
                'locale' => ''
        ],
        'code' => '',
        'expiration' => '',
        'importance' => '',
        'deliveryMode' => '',
        'listenFor' => [
                
        ],
        'textHighlights' => [
                [
                                'text' => '',
                                'occurrence' => 0
                ]
        ],
        'semanticAction' => [
                'state' => '',
                'id' => '',
                'entities' => [
                                
                ]
        ]
    ]
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'activities' => [
    [
        'type' => '',
        'id' => '',
        'timestamp' => '',
        'localTimestamp' => '',
        'localTimezone' => '',
        'callerId' => '',
        'serviceUrl' => '',
        'channelId' => '',
        'from' => [
                'id' => '',
                'name' => '',
                'aadObjectId' => '',
                'role' => ''
        ],
        'conversation' => [
                'isGroup' => null,
                'conversationType' => '',
                'tenantId' => '',
                'id' => '',
                'name' => '',
                'aadObjectId' => '',
                'role' => ''
        ],
        'recipient' => [
                
        ],
        'textFormat' => '',
        'attachmentLayout' => '',
        'membersAdded' => [
                [
                                
                ]
        ],
        'membersRemoved' => [
                [
                                
                ]
        ],
        'reactionsAdded' => [
                [
                                'type' => ''
                ]
        ],
        'reactionsRemoved' => [
                [
                                
                ]
        ],
        'topicName' => '',
        'historyDisclosed' => null,
        'locale' => '',
        'text' => '',
        'speak' => '',
        'inputHint' => '',
        'summary' => '',
        'suggestedActions' => [
                'to' => [
                                
                ],
                'actions' => [
                                [
                                                                'type' => '',
                                                                'title' => '',
                                                                'image' => '',
                                                                'imageAltText' => '',
                                                                'text' => '',
                                                                'displayText' => '',
                                                                'value' => [
                                                                                                                                
                                                                ],
                                                                'channelData' => [
                                                                                                                                
                                                                ]
                                ]
                ]
        ],
        'attachments' => [
                [
                                'contentType' => '',
                                'contentUrl' => '',
                                'content' => [
                                                                
                                ],
                                'name' => '',
                                'thumbnailUrl' => ''
                ]
        ],
        'entities' => [
                [
                                'type' => ''
                ]
        ],
        'channelData' => [
                
        ],
        'action' => '',
        'replyToId' => '',
        'label' => '',
        'valueType' => '',
        'value' => [
                
        ],
        'name' => '',
        'relatesTo' => [
                'activityId' => '',
                'user' => [
                                
                ],
                'bot' => [
                                
                ],
                'conversation' => [
                                
                ],
                'channelId' => '',
                'serviceUrl' => '',
                'locale' => ''
        ],
        'code' => '',
        'expiration' => '',
        'importance' => '',
        'deliveryMode' => '',
        'listenFor' => [
                
        ],
        'textHighlights' => [
                [
                                'text' => '',
                                'occurrence' => 0
                ]
        ],
        'semanticAction' => [
                'state' => '',
                'id' => '',
                'entities' => [
                                
                ]
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/expectedReplies');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/expectedReplies' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "activities": [
    {
      "type": "",
      "id": "",
      "timestamp": "",
      "localTimestamp": "",
      "localTimezone": "",
      "callerId": "",
      "serviceUrl": "",
      "channelId": "",
      "from": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "conversation": {
        "isGroup": false,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "recipient": {},
      "textFormat": "",
      "attachmentLayout": "",
      "membersAdded": [
        {}
      ],
      "membersRemoved": [
        {}
      ],
      "reactionsAdded": [
        {
          "type": ""
        }
      ],
      "reactionsRemoved": [
        {}
      ],
      "topicName": "",
      "historyDisclosed": false,
      "locale": "",
      "text": "",
      "speak": "",
      "inputHint": "",
      "summary": "",
      "suggestedActions": {
        "to": [],
        "actions": [
          {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
          }
        ]
      },
      "attachments": [
        {
          "contentType": "",
          "contentUrl": "",
          "content": {},
          "name": "",
          "thumbnailUrl": ""
        }
      ],
      "entities": [
        {
          "type": ""
        }
      ],
      "channelData": {},
      "action": "",
      "replyToId": "",
      "label": "",
      "valueType": "",
      "value": {},
      "name": "",
      "relatesTo": {
        "activityId": "",
        "user": {},
        "bot": {},
        "conversation": {},
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
      },
      "code": "",
      "expiration": "",
      "importance": "",
      "deliveryMode": "",
      "listenFor": [],
      "textHighlights": [
        {
          "text": "",
          "occurrence": 0
        }
      ],
      "semanticAction": {
        "state": "",
        "id": "",
        "entities": {}
      }
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/expectedReplies' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "activities": [
    {
      "type": "",
      "id": "",
      "timestamp": "",
      "localTimestamp": "",
      "localTimezone": "",
      "callerId": "",
      "serviceUrl": "",
      "channelId": "",
      "from": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "conversation": {
        "isGroup": false,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "recipient": {},
      "textFormat": "",
      "attachmentLayout": "",
      "membersAdded": [
        {}
      ],
      "membersRemoved": [
        {}
      ],
      "reactionsAdded": [
        {
          "type": ""
        }
      ],
      "reactionsRemoved": [
        {}
      ],
      "topicName": "",
      "historyDisclosed": false,
      "locale": "",
      "text": "",
      "speak": "",
      "inputHint": "",
      "summary": "",
      "suggestedActions": {
        "to": [],
        "actions": [
          {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
          }
        ]
      },
      "attachments": [
        {
          "contentType": "",
          "contentUrl": "",
          "content": {},
          "name": "",
          "thumbnailUrl": ""
        }
      ],
      "entities": [
        {
          "type": ""
        }
      ],
      "channelData": {},
      "action": "",
      "replyToId": "",
      "label": "",
      "valueType": "",
      "value": {},
      "name": "",
      "relatesTo": {
        "activityId": "",
        "user": {},
        "bot": {},
        "conversation": {},
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
      },
      "code": "",
      "expiration": "",
      "importance": "",
      "deliveryMode": "",
      "listenFor": [],
      "textHighlights": [
        {
          "text": "",
          "occurrence": 0
        }
      ],
      "semanticAction": {
        "state": "",
        "id": "",
        "entities": {}
      }
    }
  ]
}'
import http.client

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

payload = "{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}"

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

conn.request("POST", "/baseUrl/v3/connectorInternals/expectedReplies", payload, headers)

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

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

url = "{{baseUrl}}/v3/connectorInternals/expectedReplies"

payload = { "activities": [
        {
            "type": "",
            "id": "",
            "timestamp": "",
            "localTimestamp": "",
            "localTimezone": "",
            "callerId": "",
            "serviceUrl": "",
            "channelId": "",
            "from": {
                "id": "",
                "name": "",
                "aadObjectId": "",
                "role": ""
            },
            "conversation": {
                "isGroup": False,
                "conversationType": "",
                "tenantId": "",
                "id": "",
                "name": "",
                "aadObjectId": "",
                "role": ""
            },
            "recipient": {},
            "textFormat": "",
            "attachmentLayout": "",
            "membersAdded": [{}],
            "membersRemoved": [{}],
            "reactionsAdded": [{ "type": "" }],
            "reactionsRemoved": [{}],
            "topicName": "",
            "historyDisclosed": False,
            "locale": "",
            "text": "",
            "speak": "",
            "inputHint": "",
            "summary": "",
            "suggestedActions": {
                "to": [],
                "actions": [
                    {
                        "type": "",
                        "title": "",
                        "image": "",
                        "imageAltText": "",
                        "text": "",
                        "displayText": "",
                        "value": {},
                        "channelData": {}
                    }
                ]
            },
            "attachments": [
                {
                    "contentType": "",
                    "contentUrl": "",
                    "content": {},
                    "name": "",
                    "thumbnailUrl": ""
                }
            ],
            "entities": [{ "type": "" }],
            "channelData": {},
            "action": "",
            "replyToId": "",
            "label": "",
            "valueType": "",
            "value": {},
            "name": "",
            "relatesTo": {
                "activityId": "",
                "user": {},
                "bot": {},
                "conversation": {},
                "channelId": "",
                "serviceUrl": "",
                "locale": ""
            },
            "code": "",
            "expiration": "",
            "importance": "",
            "deliveryMode": "",
            "listenFor": [],
            "textHighlights": [
                {
                    "text": "",
                    "occurrence": 0
                }
            ],
            "semanticAction": {
                "state": "",
                "id": "",
                "entities": {}
            }
        }
    ] }
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3/connectorInternals/expectedReplies"

payload <- "{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v3/connectorInternals/expectedReplies")

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

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}"

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

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

response = conn.post('/baseUrl/v3/connectorInternals/expectedReplies') do |req|
  req.body = "{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}"
end

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

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

    let payload = json!({"activities": (
            json!({
                "type": "",
                "id": "",
                "timestamp": "",
                "localTimestamp": "",
                "localTimezone": "",
                "callerId": "",
                "serviceUrl": "",
                "channelId": "",
                "from": json!({
                    "id": "",
                    "name": "",
                    "aadObjectId": "",
                    "role": ""
                }),
                "conversation": json!({
                    "isGroup": false,
                    "conversationType": "",
                    "tenantId": "",
                    "id": "",
                    "name": "",
                    "aadObjectId": "",
                    "role": ""
                }),
                "recipient": json!({}),
                "textFormat": "",
                "attachmentLayout": "",
                "membersAdded": (json!({})),
                "membersRemoved": (json!({})),
                "reactionsAdded": (json!({"type": ""})),
                "reactionsRemoved": (json!({})),
                "topicName": "",
                "historyDisclosed": false,
                "locale": "",
                "text": "",
                "speak": "",
                "inputHint": "",
                "summary": "",
                "suggestedActions": json!({
                    "to": (),
                    "actions": (
                        json!({
                            "type": "",
                            "title": "",
                            "image": "",
                            "imageAltText": "",
                            "text": "",
                            "displayText": "",
                            "value": json!({}),
                            "channelData": json!({})
                        })
                    )
                }),
                "attachments": (
                    json!({
                        "contentType": "",
                        "contentUrl": "",
                        "content": json!({}),
                        "name": "",
                        "thumbnailUrl": ""
                    })
                ),
                "entities": (json!({"type": ""})),
                "channelData": json!({}),
                "action": "",
                "replyToId": "",
                "label": "",
                "valueType": "",
                "value": json!({}),
                "name": "",
                "relatesTo": json!({
                    "activityId": "",
                    "user": json!({}),
                    "bot": json!({}),
                    "conversation": json!({}),
                    "channelId": "",
                    "serviceUrl": "",
                    "locale": ""
                }),
                "code": "",
                "expiration": "",
                "importance": "",
                "deliveryMode": "",
                "listenFor": (),
                "textHighlights": (
                    json!({
                        "text": "",
                        "occurrence": 0
                    })
                ),
                "semanticAction": json!({
                    "state": "",
                    "id": "",
                    "entities": json!({})
                })
            })
        )});

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/expectedReplies \
  --header 'content-type: application/json' \
  --data '{
  "activities": [
    {
      "type": "",
      "id": "",
      "timestamp": "",
      "localTimestamp": "",
      "localTimezone": "",
      "callerId": "",
      "serviceUrl": "",
      "channelId": "",
      "from": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "conversation": {
        "isGroup": false,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "recipient": {},
      "textFormat": "",
      "attachmentLayout": "",
      "membersAdded": [
        {}
      ],
      "membersRemoved": [
        {}
      ],
      "reactionsAdded": [
        {
          "type": ""
        }
      ],
      "reactionsRemoved": [
        {}
      ],
      "topicName": "",
      "historyDisclosed": false,
      "locale": "",
      "text": "",
      "speak": "",
      "inputHint": "",
      "summary": "",
      "suggestedActions": {
        "to": [],
        "actions": [
          {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
          }
        ]
      },
      "attachments": [
        {
          "contentType": "",
          "contentUrl": "",
          "content": {},
          "name": "",
          "thumbnailUrl": ""
        }
      ],
      "entities": [
        {
          "type": ""
        }
      ],
      "channelData": {},
      "action": "",
      "replyToId": "",
      "label": "",
      "valueType": "",
      "value": {},
      "name": "",
      "relatesTo": {
        "activityId": "",
        "user": {},
        "bot": {},
        "conversation": {},
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
      },
      "code": "",
      "expiration": "",
      "importance": "",
      "deliveryMode": "",
      "listenFor": [],
      "textHighlights": [
        {
          "text": "",
          "occurrence": 0
        }
      ],
      "semanticAction": {
        "state": "",
        "id": "",
        "entities": {}
      }
    }
  ]
}'
echo '{
  "activities": [
    {
      "type": "",
      "id": "",
      "timestamp": "",
      "localTimestamp": "",
      "localTimezone": "",
      "callerId": "",
      "serviceUrl": "",
      "channelId": "",
      "from": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "conversation": {
        "isGroup": false,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "recipient": {},
      "textFormat": "",
      "attachmentLayout": "",
      "membersAdded": [
        {}
      ],
      "membersRemoved": [
        {}
      ],
      "reactionsAdded": [
        {
          "type": ""
        }
      ],
      "reactionsRemoved": [
        {}
      ],
      "topicName": "",
      "historyDisclosed": false,
      "locale": "",
      "text": "",
      "speak": "",
      "inputHint": "",
      "summary": "",
      "suggestedActions": {
        "to": [],
        "actions": [
          {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
          }
        ]
      },
      "attachments": [
        {
          "contentType": "",
          "contentUrl": "",
          "content": {},
          "name": "",
          "thumbnailUrl": ""
        }
      ],
      "entities": [
        {
          "type": ""
        }
      ],
      "channelData": {},
      "action": "",
      "replyToId": "",
      "label": "",
      "valueType": "",
      "value": {},
      "name": "",
      "relatesTo": {
        "activityId": "",
        "user": {},
        "bot": {},
        "conversation": {},
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
      },
      "code": "",
      "expiration": "",
      "importance": "",
      "deliveryMode": "",
      "listenFor": [],
      "textHighlights": [
        {
          "text": "",
          "occurrence": 0
        }
      ],
      "semanticAction": {
        "state": "",
        "id": "",
        "entities": {}
      }
    }
  ]
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/expectedReplies \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "activities": [\n    {\n      "type": "",\n      "id": "",\n      "timestamp": "",\n      "localTimestamp": "",\n      "localTimezone": "",\n      "callerId": "",\n      "serviceUrl": "",\n      "channelId": "",\n      "from": {\n        "id": "",\n        "name": "",\n        "aadObjectId": "",\n        "role": ""\n      },\n      "conversation": {\n        "isGroup": false,\n        "conversationType": "",\n        "tenantId": "",\n        "id": "",\n        "name": "",\n        "aadObjectId": "",\n        "role": ""\n      },\n      "recipient": {},\n      "textFormat": "",\n      "attachmentLayout": "",\n      "membersAdded": [\n        {}\n      ],\n      "membersRemoved": [\n        {}\n      ],\n      "reactionsAdded": [\n        {\n          "type": ""\n        }\n      ],\n      "reactionsRemoved": [\n        {}\n      ],\n      "topicName": "",\n      "historyDisclosed": false,\n      "locale": "",\n      "text": "",\n      "speak": "",\n      "inputHint": "",\n      "summary": "",\n      "suggestedActions": {\n        "to": [],\n        "actions": [\n          {\n            "type": "",\n            "title": "",\n            "image": "",\n            "imageAltText": "",\n            "text": "",\n            "displayText": "",\n            "value": {},\n            "channelData": {}\n          }\n        ]\n      },\n      "attachments": [\n        {\n          "contentType": "",\n          "contentUrl": "",\n          "content": {},\n          "name": "",\n          "thumbnailUrl": ""\n        }\n      ],\n      "entities": [\n        {\n          "type": ""\n        }\n      ],\n      "channelData": {},\n      "action": "",\n      "replyToId": "",\n      "label": "",\n      "valueType": "",\n      "value": {},\n      "name": "",\n      "relatesTo": {\n        "activityId": "",\n        "user": {},\n        "bot": {},\n        "conversation": {},\n        "channelId": "",\n        "serviceUrl": "",\n        "locale": ""\n      },\n      "code": "",\n      "expiration": "",\n      "importance": "",\n      "deliveryMode": "",\n      "listenFor": [],\n      "textHighlights": [\n        {\n          "text": "",\n          "occurrence": 0\n        }\n      ],\n      "semanticAction": {\n        "state": "",\n        "id": "",\n        "entities": {}\n      }\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/expectedReplies
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["activities": [
    [
      "type": "",
      "id": "",
      "timestamp": "",
      "localTimestamp": "",
      "localTimezone": "",
      "callerId": "",
      "serviceUrl": "",
      "channelId": "",
      "from": [
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      ],
      "conversation": [
        "isGroup": false,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      ],
      "recipient": [],
      "textFormat": "",
      "attachmentLayout": "",
      "membersAdded": [[]],
      "membersRemoved": [[]],
      "reactionsAdded": [["type": ""]],
      "reactionsRemoved": [[]],
      "topicName": "",
      "historyDisclosed": false,
      "locale": "",
      "text": "",
      "speak": "",
      "inputHint": "",
      "summary": "",
      "suggestedActions": [
        "to": [],
        "actions": [
          [
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": [],
            "channelData": []
          ]
        ]
      ],
      "attachments": [
        [
          "contentType": "",
          "contentUrl": "",
          "content": [],
          "name": "",
          "thumbnailUrl": ""
        ]
      ],
      "entities": [["type": ""]],
      "channelData": [],
      "action": "",
      "replyToId": "",
      "label": "",
      "valueType": "",
      "value": [],
      "name": "",
      "relatesTo": [
        "activityId": "",
        "user": [],
        "bot": [],
        "conversation": [],
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
      ],
      "code": "",
      "expiration": "",
      "importance": "",
      "deliveryMode": "",
      "listenFor": [],
      "textHighlights": [
        [
          "text": "",
          "occurrence": 0
        ]
      ],
      "semanticAction": [
        "state": "",
        "id": "",
        "entities": []
      ]
    ]
  ]] as [String : Any]

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

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

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

dataTask.resume()
POST PostHeroCard
{{baseUrl}}/v3/connectorInternals/heroCard
BODY json

{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/heroCard");

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  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}");

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

(client/post "{{baseUrl}}/v3/connectorInternals/heroCard" {:content-type :json
                                                                           :form-params {:title ""
                                                                                         :subtitle ""
                                                                                         :text ""
                                                                                         :images [{:url ""
                                                                                                   :alt ""
                                                                                                   :tap {:type ""
                                                                                                         :title ""
                                                                                                         :image ""
                                                                                                         :imageAltText ""
                                                                                                         :text ""
                                                                                                         :displayText ""
                                                                                                         :value {}
                                                                                                         :channelData {}}}]
                                                                                         :buttons [{}]
                                                                                         :tap {}}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/heroCard"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/heroCard"),
    Content = new StringContent("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\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}}/v3/connectorInternals/heroCard");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/heroCard"

	payload := strings.NewReader("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}")

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

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

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

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

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

}
POST /baseUrl/v3/connectorInternals/heroCard HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 361

{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/heroCard")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/heroCard"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\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  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/heroCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/heroCard")
  .header("content-type", "application/json")
  .body("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}")
  .asString();
const data = JSON.stringify({
  title: '',
  subtitle: '',
  text: '',
  images: [
    {
      url: '',
      alt: '',
      tap: {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    }
  ],
  buttons: [
    {}
  ],
  tap: {}
});

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

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

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/heroCard');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/heroCard',
  headers: {'content-type': 'application/json'},
  data: {
    title: '',
    subtitle: '',
    text: '',
    images: [
      {
        url: '',
        alt: '',
        tap: {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      }
    ],
    buttons: [{}],
    tap: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/heroCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"title":"","subtitle":"","text":"","images":[{"url":"","alt":"","tap":{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}}],"buttons":[{}],"tap":{}}'
};

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}}/v3/connectorInternals/heroCard',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "title": "",\n  "subtitle": "",\n  "text": "",\n  "images": [\n    {\n      "url": "",\n      "alt": "",\n      "tap": {\n        "type": "",\n        "title": "",\n        "image": "",\n        "imageAltText": "",\n        "text": "",\n        "displayText": "",\n        "value": {},\n        "channelData": {}\n      }\n    }\n  ],\n  "buttons": [\n    {}\n  ],\n  "tap": {}\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/heroCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/heroCard',
  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({
  title: '',
  subtitle: '',
  text: '',
  images: [
    {
      url: '',
      alt: '',
      tap: {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    }
  ],
  buttons: [{}],
  tap: {}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/heroCard',
  headers: {'content-type': 'application/json'},
  body: {
    title: '',
    subtitle: '',
    text: '',
    images: [
      {
        url: '',
        alt: '',
        tap: {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      }
    ],
    buttons: [{}],
    tap: {}
  },
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/heroCard');

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

req.type('json');
req.send({
  title: '',
  subtitle: '',
  text: '',
  images: [
    {
      url: '',
      alt: '',
      tap: {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    }
  ],
  buttons: [
    {}
  ],
  tap: {}
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/heroCard',
  headers: {'content-type': 'application/json'},
  data: {
    title: '',
    subtitle: '',
    text: '',
    images: [
      {
        url: '',
        alt: '',
        tap: {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      }
    ],
    buttons: [{}],
    tap: {}
  }
};

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

const url = '{{baseUrl}}/v3/connectorInternals/heroCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"title":"","subtitle":"","text":"","images":[{"url":"","alt":"","tap":{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}}],"buttons":[{}],"tap":{}}'
};

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 = @{ @"title": @"",
                              @"subtitle": @"",
                              @"text": @"",
                              @"images": @[ @{ @"url": @"", @"alt": @"", @"tap": @{ @"type": @"", @"title": @"", @"image": @"", @"imageAltText": @"", @"text": @"", @"displayText": @"", @"value": @{  }, @"channelData": @{  } } } ],
                              @"buttons": @[ @{  } ],
                              @"tap": @{  } };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/heroCard" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/heroCard",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'title' => '',
    'subtitle' => '',
    'text' => '',
    'images' => [
        [
                'url' => '',
                'alt' => '',
                'tap' => [
                                'type' => '',
                                'title' => '',
                                'image' => '',
                                'imageAltText' => '',
                                'text' => '',
                                'displayText' => '',
                                'value' => [
                                                                
                                ],
                                'channelData' => [
                                                                
                                ]
                ]
        ]
    ],
    'buttons' => [
        [
                
        ]
    ],
    'tap' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/heroCard', [
  'body' => '{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/heroCard');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'title' => '',
  'subtitle' => '',
  'text' => '',
  'images' => [
    [
        'url' => '',
        'alt' => '',
        'tap' => [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ]
  ],
  'buttons' => [
    [
        
    ]
  ],
  'tap' => [
    
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'title' => '',
  'subtitle' => '',
  'text' => '',
  'images' => [
    [
        'url' => '',
        'alt' => '',
        'tap' => [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ]
  ],
  'buttons' => [
    [
        
    ]
  ],
  'tap' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/heroCard');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/heroCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/heroCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}'
import http.client

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

payload = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}"

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

conn.request("POST", "/baseUrl/v3/connectorInternals/heroCard", payload, headers)

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

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

url = "{{baseUrl}}/v3/connectorInternals/heroCard"

payload = {
    "title": "",
    "subtitle": "",
    "text": "",
    "images": [
        {
            "url": "",
            "alt": "",
            "tap": {
                "type": "",
                "title": "",
                "image": "",
                "imageAltText": "",
                "text": "",
                "displayText": "",
                "value": {},
                "channelData": {}
            }
        }
    ],
    "buttons": [{}],
    "tap": {}
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3/connectorInternals/heroCard"

payload <- "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v3/connectorInternals/heroCard")

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

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}"

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

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

response = conn.post('/baseUrl/v3/connectorInternals/heroCard') do |req|
  req.body = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}"
end

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

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

    let payload = json!({
        "title": "",
        "subtitle": "",
        "text": "",
        "images": (
            json!({
                "url": "",
                "alt": "",
                "tap": json!({
                    "type": "",
                    "title": "",
                    "image": "",
                    "imageAltText": "",
                    "text": "",
                    "displayText": "",
                    "value": json!({}),
                    "channelData": json!({})
                })
            })
        ),
        "buttons": (json!({})),
        "tap": json!({})
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/heroCard \
  --header 'content-type: application/json' \
  --data '{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}'
echo '{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/heroCard \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "title": "",\n  "subtitle": "",\n  "text": "",\n  "images": [\n    {\n      "url": "",\n      "alt": "",\n      "tap": {\n        "type": "",\n        "title": "",\n        "image": "",\n        "imageAltText": "",\n        "text": "",\n        "displayText": "",\n        "value": {},\n        "channelData": {}\n      }\n    }\n  ],\n  "buttons": [\n    {}\n  ],\n  "tap": {}\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/heroCard
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    [
      "url": "",
      "alt": "",
      "tap": [
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": [],
        "channelData": []
      ]
    ]
  ],
  "buttons": [[]],
  "tap": []
] as [String : Any]

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

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

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

dataTask.resume()
POST PostInvokeResponse
{{baseUrl}}/v3/connectorInternals/invokeResponse
BODY json

{
  "status": 0,
  "body": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/invokeResponse");

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  \"status\": 0,\n  \"body\": {}\n}");

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

(client/post "{{baseUrl}}/v3/connectorInternals/invokeResponse" {:content-type :json
                                                                                 :form-params {:status 0
                                                                                               :body {}}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/invokeResponse"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"status\": 0,\n  \"body\": {}\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/invokeResponse"),
    Content = new StringContent("{\n  \"status\": 0,\n  \"body\": {}\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}}/v3/connectorInternals/invokeResponse");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"status\": 0,\n  \"body\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/invokeResponse"

	payload := strings.NewReader("{\n  \"status\": 0,\n  \"body\": {}\n}")

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

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

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

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

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

}
POST /baseUrl/v3/connectorInternals/invokeResponse HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 31

{
  "status": 0,
  "body": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/invokeResponse")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"status\": 0,\n  \"body\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

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

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

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

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/invokeResponse');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/invokeResponse',
  headers: {'content-type': 'application/json'},
  data: {status: 0, body: {}}
};

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

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

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"status\": 0,\n  \"body\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/invokeResponse")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/invokeResponse',
  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({status: 0, body: {}}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/invokeResponse',
  headers: {'content-type': 'application/json'},
  body: {status: 0, body: {}},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/invokeResponse');

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

req.type('json');
req.send({
  status: 0,
  body: {}
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/invokeResponse',
  headers: {'content-type': 'application/json'},
  data: {status: 0, body: {}}
};

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

const url = '{{baseUrl}}/v3/connectorInternals/invokeResponse';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"status":0,"body":{}}'
};

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

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

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/invokeResponse" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"status\": 0,\n  \"body\": {}\n}" in

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

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

curl_close($curl);

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

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/invokeResponse');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'status' => 0,
  'body' => [
    
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'status' => 0,
  'body' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/invokeResponse');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/invokeResponse' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "status": 0,
  "body": {}
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/invokeResponse' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "status": 0,
  "body": {}
}'
import http.client

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

payload = "{\n  \"status\": 0,\n  \"body\": {}\n}"

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

conn.request("POST", "/baseUrl/v3/connectorInternals/invokeResponse", payload, headers)

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

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

url = "{{baseUrl}}/v3/connectorInternals/invokeResponse"

payload = {
    "status": 0,
    "body": {}
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3/connectorInternals/invokeResponse"

payload <- "{\n  \"status\": 0,\n  \"body\": {}\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v3/connectorInternals/invokeResponse")

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

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

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

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

response = conn.post('/baseUrl/v3/connectorInternals/invokeResponse') do |req|
  req.body = "{\n  \"status\": 0,\n  \"body\": {}\n}"
end

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

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

    let payload = json!({
        "status": 0,
        "body": json!({})
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/invokeResponse \
  --header 'content-type: application/json' \
  --data '{
  "status": 0,
  "body": {}
}'
echo '{
  "status": 0,
  "body": {}
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/invokeResponse \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "status": 0,\n  "body": {}\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/invokeResponse
import Foundation

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

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

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

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

dataTask.resume()
POST PostMediaCard
{{baseUrl}}/v3/connectorInternals/mediaCard
BODY json

{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/mediaCard");

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  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}");

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

(client/post "{{baseUrl}}/v3/connectorInternals/mediaCard" {:content-type :json
                                                                            :form-params {:title ""
                                                                                          :subtitle ""
                                                                                          :text ""
                                                                                          :image {:url ""
                                                                                                  :alt ""}
                                                                                          :media [{:url ""
                                                                                                   :profile ""}]
                                                                                          :buttons [{:type ""
                                                                                                     :title ""
                                                                                                     :image ""
                                                                                                     :imageAltText ""
                                                                                                     :text ""
                                                                                                     :displayText ""
                                                                                                     :value {}
                                                                                                     :channelData {}}]
                                                                                          :shareable false
                                                                                          :autoloop false
                                                                                          :autostart false
                                                                                          :aspect ""
                                                                                          :duration ""
                                                                                          :value {}}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/mediaCard"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/mediaCard"),
    Content = new StringContent("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\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}}/v3/connectorInternals/mediaCard");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/mediaCard"

	payload := strings.NewReader("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}")

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

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

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

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

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

}
POST /baseUrl/v3/connectorInternals/mediaCard HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 477

{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/mediaCard")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/mediaCard"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\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  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/mediaCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/mediaCard")
  .header("content-type", "application/json")
  .body("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}")
  .asString();
const data = JSON.stringify({
  title: '',
  subtitle: '',
  text: '',
  image: {
    url: '',
    alt: ''
  },
  media: [
    {
      url: '',
      profile: ''
    }
  ],
  buttons: [
    {
      type: '',
      title: '',
      image: '',
      imageAltText: '',
      text: '',
      displayText: '',
      value: {},
      channelData: {}
    }
  ],
  shareable: false,
  autoloop: false,
  autostart: false,
  aspect: '',
  duration: '',
  value: {}
});

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

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

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/mediaCard');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/mediaCard',
  headers: {'content-type': 'application/json'},
  data: {
    title: '',
    subtitle: '',
    text: '',
    image: {url: '', alt: ''},
    media: [{url: '', profile: ''}],
    buttons: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ],
    shareable: false,
    autoloop: false,
    autostart: false,
    aspect: '',
    duration: '',
    value: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/mediaCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"title":"","subtitle":"","text":"","image":{"url":"","alt":""},"media":[{"url":"","profile":""}],"buttons":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}],"shareable":false,"autoloop":false,"autostart":false,"aspect":"","duration":"","value":{}}'
};

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}}/v3/connectorInternals/mediaCard',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "title": "",\n  "subtitle": "",\n  "text": "",\n  "image": {\n    "url": "",\n    "alt": ""\n  },\n  "media": [\n    {\n      "url": "",\n      "profile": ""\n    }\n  ],\n  "buttons": [\n    {\n      "type": "",\n      "title": "",\n      "image": "",\n      "imageAltText": "",\n      "text": "",\n      "displayText": "",\n      "value": {},\n      "channelData": {}\n    }\n  ],\n  "shareable": false,\n  "autoloop": false,\n  "autostart": false,\n  "aspect": "",\n  "duration": "",\n  "value": {}\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/mediaCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/mediaCard',
  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({
  title: '',
  subtitle: '',
  text: '',
  image: {url: '', alt: ''},
  media: [{url: '', profile: ''}],
  buttons: [
    {
      type: '',
      title: '',
      image: '',
      imageAltText: '',
      text: '',
      displayText: '',
      value: {},
      channelData: {}
    }
  ],
  shareable: false,
  autoloop: false,
  autostart: false,
  aspect: '',
  duration: '',
  value: {}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/mediaCard',
  headers: {'content-type': 'application/json'},
  body: {
    title: '',
    subtitle: '',
    text: '',
    image: {url: '', alt: ''},
    media: [{url: '', profile: ''}],
    buttons: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ],
    shareable: false,
    autoloop: false,
    autostart: false,
    aspect: '',
    duration: '',
    value: {}
  },
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/mediaCard');

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

req.type('json');
req.send({
  title: '',
  subtitle: '',
  text: '',
  image: {
    url: '',
    alt: ''
  },
  media: [
    {
      url: '',
      profile: ''
    }
  ],
  buttons: [
    {
      type: '',
      title: '',
      image: '',
      imageAltText: '',
      text: '',
      displayText: '',
      value: {},
      channelData: {}
    }
  ],
  shareable: false,
  autoloop: false,
  autostart: false,
  aspect: '',
  duration: '',
  value: {}
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/mediaCard',
  headers: {'content-type': 'application/json'},
  data: {
    title: '',
    subtitle: '',
    text: '',
    image: {url: '', alt: ''},
    media: [{url: '', profile: ''}],
    buttons: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ],
    shareable: false,
    autoloop: false,
    autostart: false,
    aspect: '',
    duration: '',
    value: {}
  }
};

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

const url = '{{baseUrl}}/v3/connectorInternals/mediaCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"title":"","subtitle":"","text":"","image":{"url":"","alt":""},"media":[{"url":"","profile":""}],"buttons":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}],"shareable":false,"autoloop":false,"autostart":false,"aspect":"","duration":"","value":{}}'
};

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 = @{ @"title": @"",
                              @"subtitle": @"",
                              @"text": @"",
                              @"image": @{ @"url": @"", @"alt": @"" },
                              @"media": @[ @{ @"url": @"", @"profile": @"" } ],
                              @"buttons": @[ @{ @"type": @"", @"title": @"", @"image": @"", @"imageAltText": @"", @"text": @"", @"displayText": @"", @"value": @{  }, @"channelData": @{  } } ],
                              @"shareable": @NO,
                              @"autoloop": @NO,
                              @"autostart": @NO,
                              @"aspect": @"",
                              @"duration": @"",
                              @"value": @{  } };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/mediaCard" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/mediaCard",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'title' => '',
    'subtitle' => '',
    'text' => '',
    'image' => [
        'url' => '',
        'alt' => ''
    ],
    'media' => [
        [
                'url' => '',
                'profile' => ''
        ]
    ],
    'buttons' => [
        [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ],
    'shareable' => null,
    'autoloop' => null,
    'autostart' => null,
    'aspect' => '',
    'duration' => '',
    'value' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/mediaCard', [
  'body' => '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/mediaCard');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'title' => '',
  'subtitle' => '',
  'text' => '',
  'image' => [
    'url' => '',
    'alt' => ''
  ],
  'media' => [
    [
        'url' => '',
        'profile' => ''
    ]
  ],
  'buttons' => [
    [
        'type' => '',
        'title' => '',
        'image' => '',
        'imageAltText' => '',
        'text' => '',
        'displayText' => '',
        'value' => [
                
        ],
        'channelData' => [
                
        ]
    ]
  ],
  'shareable' => null,
  'autoloop' => null,
  'autostart' => null,
  'aspect' => '',
  'duration' => '',
  'value' => [
    
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'title' => '',
  'subtitle' => '',
  'text' => '',
  'image' => [
    'url' => '',
    'alt' => ''
  ],
  'media' => [
    [
        'url' => '',
        'profile' => ''
    ]
  ],
  'buttons' => [
    [
        'type' => '',
        'title' => '',
        'image' => '',
        'imageAltText' => '',
        'text' => '',
        'displayText' => '',
        'value' => [
                
        ],
        'channelData' => [
                
        ]
    ]
  ],
  'shareable' => null,
  'autoloop' => null,
  'autostart' => null,
  'aspect' => '',
  'duration' => '',
  'value' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/mediaCard');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/mediaCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/mediaCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}'
import http.client

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

payload = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"

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

conn.request("POST", "/baseUrl/v3/connectorInternals/mediaCard", payload, headers)

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

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

url = "{{baseUrl}}/v3/connectorInternals/mediaCard"

payload = {
    "title": "",
    "subtitle": "",
    "text": "",
    "image": {
        "url": "",
        "alt": ""
    },
    "media": [
        {
            "url": "",
            "profile": ""
        }
    ],
    "buttons": [
        {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
        }
    ],
    "shareable": False,
    "autoloop": False,
    "autostart": False,
    "aspect": "",
    "duration": "",
    "value": {}
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3/connectorInternals/mediaCard"

payload <- "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v3/connectorInternals/mediaCard")

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

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"

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

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

response = conn.post('/baseUrl/v3/connectorInternals/mediaCard') do |req|
  req.body = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"
end

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

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

    let payload = json!({
        "title": "",
        "subtitle": "",
        "text": "",
        "image": json!({
            "url": "",
            "alt": ""
        }),
        "media": (
            json!({
                "url": "",
                "profile": ""
            })
        ),
        "buttons": (
            json!({
                "type": "",
                "title": "",
                "image": "",
                "imageAltText": "",
                "text": "",
                "displayText": "",
                "value": json!({}),
                "channelData": json!({})
            })
        ),
        "shareable": false,
        "autoloop": false,
        "autostart": false,
        "aspect": "",
        "duration": "",
        "value": json!({})
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/mediaCard \
  --header 'content-type: application/json' \
  --data '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}'
echo '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/mediaCard \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "title": "",\n  "subtitle": "",\n  "text": "",\n  "image": {\n    "url": "",\n    "alt": ""\n  },\n  "media": [\n    {\n      "url": "",\n      "profile": ""\n    }\n  ],\n  "buttons": [\n    {\n      "type": "",\n      "title": "",\n      "image": "",\n      "imageAltText": "",\n      "text": "",\n      "displayText": "",\n      "value": {},\n      "channelData": {}\n    }\n  ],\n  "shareable": false,\n  "autoloop": false,\n  "autostart": false,\n  "aspect": "",\n  "duration": "",\n  "value": {}\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/mediaCard
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "title": "",
  "subtitle": "",
  "text": "",
  "image": [
    "url": "",
    "alt": ""
  ],
  "media": [
    [
      "url": "",
      "profile": ""
    ]
  ],
  "buttons": [
    [
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": [],
      "channelData": []
    ]
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": []
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/connectorInternals/mediaCard")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST PostMention
{{baseUrl}}/v3/connectorInternals/mention
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/mention");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/connectorInternals/mention")
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/mention"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/mention"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3/connectorInternals/mention");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/mention"

	req, _ := http.NewRequest("POST", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/connectorInternals/mention HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/mention")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/mention"))
    .method("POST", 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}}/v3/connectorInternals/mention")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/mention")
  .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('POST', '{{baseUrl}}/v3/connectorInternals/mention');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/mention'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/mention';
const options = {method: 'POST'};

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}}/v3/connectorInternals/mention',
  method: 'POST',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/mention")
  .post(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/mention',
  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: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/mention'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/mention');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/mention'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/connectorInternals/mention';
const options = {method: 'POST'};

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}}/v3/connectorInternals/mention"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

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}}/v3/connectorInternals/mention" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/mention",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/mention');

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/mention');
$request->setMethod(HTTP_METH_POST);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v3/connectorInternals/mention');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/mention' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/mention' -Method POST 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("POST", "/baseUrl/v3/connectorInternals/mention")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/connectorInternals/mention"

response = requests.post(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/connectorInternals/mention"

response <- VERB("POST", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/connectorInternals/mention")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.post('/baseUrl/v3/connectorInternals/mention') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/connectorInternals/mention";

    let client = reqwest::Client::new();
    let response = client.post(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/mention
http POST {{baseUrl}}/v3/connectorInternals/mention
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/mention
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/connectorInternals/mention")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST PostOAuthCard
{{baseUrl}}/v3/connectorInternals/oAuthCard
BODY json

{
  "text": "",
  "connectionName": "",
  "tokenExchangeResource": {
    "id": "",
    "uri": "",
    "providerId": ""
  },
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/oAuthCard");

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  \"text\": \"\",\n  \"connectionName\": \"\",\n  \"tokenExchangeResource\": {\n    \"id\": \"\",\n    \"uri\": \"\",\n    \"providerId\": \"\"\n  },\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/connectorInternals/oAuthCard" {:content-type :json
                                                                            :form-params {:text ""
                                                                                          :connectionName ""
                                                                                          :tokenExchangeResource {:id ""
                                                                                                                  :uri ""
                                                                                                                  :providerId ""}
                                                                                          :buttons [{:type ""
                                                                                                     :title ""
                                                                                                     :image ""
                                                                                                     :imageAltText ""
                                                                                                     :text ""
                                                                                                     :displayText ""
                                                                                                     :value {}
                                                                                                     :channelData {}}]}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/oAuthCard"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"text\": \"\",\n  \"connectionName\": \"\",\n  \"tokenExchangeResource\": {\n    \"id\": \"\",\n    \"uri\": \"\",\n    \"providerId\": \"\"\n  },\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/oAuthCard"),
    Content = new StringContent("{\n  \"text\": \"\",\n  \"connectionName\": \"\",\n  \"tokenExchangeResource\": {\n    \"id\": \"\",\n    \"uri\": \"\",\n    \"providerId\": \"\"\n  },\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3/connectorInternals/oAuthCard");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"text\": \"\",\n  \"connectionName\": \"\",\n  \"tokenExchangeResource\": {\n    \"id\": \"\",\n    \"uri\": \"\",\n    \"providerId\": \"\"\n  },\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/oAuthCard"

	payload := strings.NewReader("{\n  \"text\": \"\",\n  \"connectionName\": \"\",\n  \"tokenExchangeResource\": {\n    \"id\": \"\",\n    \"uri\": \"\",\n    \"providerId\": \"\"\n  },\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/connectorInternals/oAuthCard HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 324

{
  "text": "",
  "connectionName": "",
  "tokenExchangeResource": {
    "id": "",
    "uri": "",
    "providerId": ""
  },
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/oAuthCard")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"text\": \"\",\n  \"connectionName\": \"\",\n  \"tokenExchangeResource\": {\n    \"id\": \"\",\n    \"uri\": \"\",\n    \"providerId\": \"\"\n  },\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/oAuthCard"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"text\": \"\",\n  \"connectionName\": \"\",\n  \"tokenExchangeResource\": {\n    \"id\": \"\",\n    \"uri\": \"\",\n    \"providerId\": \"\"\n  },\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"text\": \"\",\n  \"connectionName\": \"\",\n  \"tokenExchangeResource\": {\n    \"id\": \"\",\n    \"uri\": \"\",\n    \"providerId\": \"\"\n  },\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/oAuthCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/oAuthCard")
  .header("content-type", "application/json")
  .body("{\n  \"text\": \"\",\n  \"connectionName\": \"\",\n  \"tokenExchangeResource\": {\n    \"id\": \"\",\n    \"uri\": \"\",\n    \"providerId\": \"\"\n  },\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  text: '',
  connectionName: '',
  tokenExchangeResource: {
    id: '',
    uri: '',
    providerId: ''
  },
  buttons: [
    {
      type: '',
      title: '',
      image: '',
      imageAltText: '',
      text: '',
      displayText: '',
      value: {},
      channelData: {}
    }
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/oAuthCard');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/oAuthCard',
  headers: {'content-type': 'application/json'},
  data: {
    text: '',
    connectionName: '',
    tokenExchangeResource: {id: '', uri: '', providerId: ''},
    buttons: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/oAuthCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"text":"","connectionName":"","tokenExchangeResource":{"id":"","uri":"","providerId":""},"buttons":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}]}'
};

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}}/v3/connectorInternals/oAuthCard',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "text": "",\n  "connectionName": "",\n  "tokenExchangeResource": {\n    "id": "",\n    "uri": "",\n    "providerId": ""\n  },\n  "buttons": [\n    {\n      "type": "",\n      "title": "",\n      "image": "",\n      "imageAltText": "",\n      "text": "",\n      "displayText": "",\n      "value": {},\n      "channelData": {}\n    }\n  ]\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"text\": \"\",\n  \"connectionName\": \"\",\n  \"tokenExchangeResource\": {\n    \"id\": \"\",\n    \"uri\": \"\",\n    \"providerId\": \"\"\n  },\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/oAuthCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/oAuthCard',
  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({
  text: '',
  connectionName: '',
  tokenExchangeResource: {id: '', uri: '', providerId: ''},
  buttons: [
    {
      type: '',
      title: '',
      image: '',
      imageAltText: '',
      text: '',
      displayText: '',
      value: {},
      channelData: {}
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/oAuthCard',
  headers: {'content-type': 'application/json'},
  body: {
    text: '',
    connectionName: '',
    tokenExchangeResource: {id: '', uri: '', providerId: ''},
    buttons: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ]
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/oAuthCard');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  text: '',
  connectionName: '',
  tokenExchangeResource: {
    id: '',
    uri: '',
    providerId: ''
  },
  buttons: [
    {
      type: '',
      title: '',
      image: '',
      imageAltText: '',
      text: '',
      displayText: '',
      value: {},
      channelData: {}
    }
  ]
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/oAuthCard',
  headers: {'content-type': 'application/json'},
  data: {
    text: '',
    connectionName: '',
    tokenExchangeResource: {id: '', uri: '', providerId: ''},
    buttons: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/connectorInternals/oAuthCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"text":"","connectionName":"","tokenExchangeResource":{"id":"","uri":"","providerId":""},"buttons":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}]}'
};

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 = @{ @"text": @"",
                              @"connectionName": @"",
                              @"tokenExchangeResource": @{ @"id": @"", @"uri": @"", @"providerId": @"" },
                              @"buttons": @[ @{ @"type": @"", @"title": @"", @"image": @"", @"imageAltText": @"", @"text": @"", @"displayText": @"", @"value": @{  }, @"channelData": @{  } } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/connectorInternals/oAuthCard"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/oAuthCard" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"text\": \"\",\n  \"connectionName\": \"\",\n  \"tokenExchangeResource\": {\n    \"id\": \"\",\n    \"uri\": \"\",\n    \"providerId\": \"\"\n  },\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/oAuthCard",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'text' => '',
    'connectionName' => '',
    'tokenExchangeResource' => [
        'id' => '',
        'uri' => '',
        'providerId' => ''
    ],
    'buttons' => [
        [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/oAuthCard', [
  'body' => '{
  "text": "",
  "connectionName": "",
  "tokenExchangeResource": {
    "id": "",
    "uri": "",
    "providerId": ""
  },
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/oAuthCard');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'text' => '',
  'connectionName' => '',
  'tokenExchangeResource' => [
    'id' => '',
    'uri' => '',
    'providerId' => ''
  ],
  'buttons' => [
    [
        'type' => '',
        'title' => '',
        'image' => '',
        'imageAltText' => '',
        'text' => '',
        'displayText' => '',
        'value' => [
                
        ],
        'channelData' => [
                
        ]
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'text' => '',
  'connectionName' => '',
  'tokenExchangeResource' => [
    'id' => '',
    'uri' => '',
    'providerId' => ''
  ],
  'buttons' => [
    [
        'type' => '',
        'title' => '',
        'image' => '',
        'imageAltText' => '',
        'text' => '',
        'displayText' => '',
        'value' => [
                
        ],
        'channelData' => [
                
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/oAuthCard');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/oAuthCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "text": "",
  "connectionName": "",
  "tokenExchangeResource": {
    "id": "",
    "uri": "",
    "providerId": ""
  },
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/oAuthCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "text": "",
  "connectionName": "",
  "tokenExchangeResource": {
    "id": "",
    "uri": "",
    "providerId": ""
  },
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"text\": \"\",\n  \"connectionName\": \"\",\n  \"tokenExchangeResource\": {\n    \"id\": \"\",\n    \"uri\": \"\",\n    \"providerId\": \"\"\n  },\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/connectorInternals/oAuthCard", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/connectorInternals/oAuthCard"

payload = {
    "text": "",
    "connectionName": "",
    "tokenExchangeResource": {
        "id": "",
        "uri": "",
        "providerId": ""
    },
    "buttons": [
        {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
        }
    ]
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/connectorInternals/oAuthCard"

payload <- "{\n  \"text\": \"\",\n  \"connectionName\": \"\",\n  \"tokenExchangeResource\": {\n    \"id\": \"\",\n    \"uri\": \"\",\n    \"providerId\": \"\"\n  },\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/connectorInternals/oAuthCard")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"text\": \"\",\n  \"connectionName\": \"\",\n  \"tokenExchangeResource\": {\n    \"id\": \"\",\n    \"uri\": \"\",\n    \"providerId\": \"\"\n  },\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/connectorInternals/oAuthCard') do |req|
  req.body = "{\n  \"text\": \"\",\n  \"connectionName\": \"\",\n  \"tokenExchangeResource\": {\n    \"id\": \"\",\n    \"uri\": \"\",\n    \"providerId\": \"\"\n  },\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/connectorInternals/oAuthCard";

    let payload = json!({
        "text": "",
        "connectionName": "",
        "tokenExchangeResource": json!({
            "id": "",
            "uri": "",
            "providerId": ""
        }),
        "buttons": (
            json!({
                "type": "",
                "title": "",
                "image": "",
                "imageAltText": "",
                "text": "",
                "displayText": "",
                "value": json!({}),
                "channelData": json!({})
            })
        )
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/oAuthCard \
  --header 'content-type: application/json' \
  --data '{
  "text": "",
  "connectionName": "",
  "tokenExchangeResource": {
    "id": "",
    "uri": "",
    "providerId": ""
  },
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ]
}'
echo '{
  "text": "",
  "connectionName": "",
  "tokenExchangeResource": {
    "id": "",
    "uri": "",
    "providerId": ""
  },
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ]
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/oAuthCard \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "text": "",\n  "connectionName": "",\n  "tokenExchangeResource": {\n    "id": "",\n    "uri": "",\n    "providerId": ""\n  },\n  "buttons": [\n    {\n      "type": "",\n      "title": "",\n      "image": "",\n      "imageAltText": "",\n      "text": "",\n      "displayText": "",\n      "value": {},\n      "channelData": {}\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/oAuthCard
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "text": "",
  "connectionName": "",
  "tokenExchangeResource": [
    "id": "",
    "uri": "",
    "providerId": ""
  ],
  "buttons": [
    [
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": [],
      "channelData": []
    ]
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/connectorInternals/oAuthCard")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST PostPagedMembersResult
{{baseUrl}}/v3/connectorInternals/pagedMembersResult
BODY json

{
  "continuationToken": "",
  "members": [
    {
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/pagedMembersResult");

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  \"continuationToken\": \"\",\n  \"members\": [\n    {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/connectorInternals/pagedMembersResult" {:content-type :json
                                                                                     :form-params {:continuationToken ""
                                                                                                   :members [{:id ""
                                                                                                              :name ""
                                                                                                              :aadObjectId ""
                                                                                                              :role ""}]}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/pagedMembersResult"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"continuationToken\": \"\",\n  \"members\": [\n    {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    }\n  ]\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/pagedMembersResult"),
    Content = new StringContent("{\n  \"continuationToken\": \"\",\n  \"members\": [\n    {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    }\n  ]\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3/connectorInternals/pagedMembersResult");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"continuationToken\": \"\",\n  \"members\": [\n    {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/pagedMembersResult"

	payload := strings.NewReader("{\n  \"continuationToken\": \"\",\n  \"members\": [\n    {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/connectorInternals/pagedMembersResult HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 137

{
  "continuationToken": "",
  "members": [
    {
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/pagedMembersResult")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"continuationToken\": \"\",\n  \"members\": [\n    {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/pagedMembersResult"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"continuationToken\": \"\",\n  \"members\": [\n    {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    }\n  ]\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"continuationToken\": \"\",\n  \"members\": [\n    {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/pagedMembersResult")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/pagedMembersResult")
  .header("content-type", "application/json")
  .body("{\n  \"continuationToken\": \"\",\n  \"members\": [\n    {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  continuationToken: '',
  members: [
    {
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    }
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/pagedMembersResult');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/pagedMembersResult',
  headers: {'content-type': 'application/json'},
  data: {
    continuationToken: '',
    members: [{id: '', name: '', aadObjectId: '', role: ''}]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/pagedMembersResult';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"continuationToken":"","members":[{"id":"","name":"","aadObjectId":"","role":""}]}'
};

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}}/v3/connectorInternals/pagedMembersResult',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "continuationToken": "",\n  "members": [\n    {\n      "id": "",\n      "name": "",\n      "aadObjectId": "",\n      "role": ""\n    }\n  ]\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"continuationToken\": \"\",\n  \"members\": [\n    {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/pagedMembersResult")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/pagedMembersResult',
  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({
  continuationToken: '',
  members: [{id: '', name: '', aadObjectId: '', role: ''}]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/pagedMembersResult',
  headers: {'content-type': 'application/json'},
  body: {
    continuationToken: '',
    members: [{id: '', name: '', aadObjectId: '', role: ''}]
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/pagedMembersResult');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  continuationToken: '',
  members: [
    {
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    }
  ]
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/pagedMembersResult',
  headers: {'content-type': 'application/json'},
  data: {
    continuationToken: '',
    members: [{id: '', name: '', aadObjectId: '', role: ''}]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/connectorInternals/pagedMembersResult';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"continuationToken":"","members":[{"id":"","name":"","aadObjectId":"","role":""}]}'
};

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 = @{ @"continuationToken": @"",
                              @"members": @[ @{ @"id": @"", @"name": @"", @"aadObjectId": @"", @"role": @"" } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/connectorInternals/pagedMembersResult"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/pagedMembersResult" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"continuationToken\": \"\",\n  \"members\": [\n    {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/pagedMembersResult",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'continuationToken' => '',
    'members' => [
        [
                'id' => '',
                'name' => '',
                'aadObjectId' => '',
                'role' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/pagedMembersResult', [
  'body' => '{
  "continuationToken": "",
  "members": [
    {
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/pagedMembersResult');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'continuationToken' => '',
  'members' => [
    [
        'id' => '',
        'name' => '',
        'aadObjectId' => '',
        'role' => ''
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'continuationToken' => '',
  'members' => [
    [
        'id' => '',
        'name' => '',
        'aadObjectId' => '',
        'role' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/pagedMembersResult');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/pagedMembersResult' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "continuationToken": "",
  "members": [
    {
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/pagedMembersResult' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "continuationToken": "",
  "members": [
    {
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"continuationToken\": \"\",\n  \"members\": [\n    {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/connectorInternals/pagedMembersResult", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/connectorInternals/pagedMembersResult"

payload = {
    "continuationToken": "",
    "members": [
        {
            "id": "",
            "name": "",
            "aadObjectId": "",
            "role": ""
        }
    ]
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/connectorInternals/pagedMembersResult"

payload <- "{\n  \"continuationToken\": \"\",\n  \"members\": [\n    {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/connectorInternals/pagedMembersResult")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"continuationToken\": \"\",\n  \"members\": [\n    {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    }\n  ]\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/connectorInternals/pagedMembersResult') do |req|
  req.body = "{\n  \"continuationToken\": \"\",\n  \"members\": [\n    {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    }\n  ]\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/connectorInternals/pagedMembersResult";

    let payload = json!({
        "continuationToken": "",
        "members": (
            json!({
                "id": "",
                "name": "",
                "aadObjectId": "",
                "role": ""
            })
        )
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/pagedMembersResult \
  --header 'content-type: application/json' \
  --data '{
  "continuationToken": "",
  "members": [
    {
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    }
  ]
}'
echo '{
  "continuationToken": "",
  "members": [
    {
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    }
  ]
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/pagedMembersResult \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "continuationToken": "",\n  "members": [\n    {\n      "id": "",\n      "name": "",\n      "aadObjectId": "",\n      "role": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/pagedMembersResult
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "continuationToken": "",
  "members": [
    [
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    ]
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/connectorInternals/pagedMembersResult")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST PostReceiptCard
{{baseUrl}}/v3/connectorInternals/receiptCard
BODY json

{
  "title": "",
  "facts": [
    {
      "key": "",
      "value": ""
    }
  ],
  "items": [
    {
      "title": "",
      "subtitle": "",
      "text": "",
      "image": {
        "url": "",
        "alt": "",
        "tap": {
          "type": "",
          "title": "",
          "image": "",
          "imageAltText": "",
          "text": "",
          "displayText": "",
          "value": {},
          "channelData": {}
        }
      },
      "price": "",
      "quantity": "",
      "tap": {}
    }
  ],
  "tap": {},
  "total": "",
  "tax": "",
  "vat": "",
  "buttons": [
    {}
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/receiptCard");

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  \"title\": \"\",\n  \"facts\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"items\": [\n    {\n      \"title\": \"\",\n      \"subtitle\": \"\",\n      \"text\": \"\",\n      \"image\": {\n        \"url\": \"\",\n        \"alt\": \"\",\n        \"tap\": {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      },\n      \"price\": \"\",\n      \"quantity\": \"\",\n      \"tap\": {}\n    }\n  ],\n  \"tap\": {},\n  \"total\": \"\",\n  \"tax\": \"\",\n  \"vat\": \"\",\n  \"buttons\": [\n    {}\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/connectorInternals/receiptCard" {:content-type :json
                                                                              :form-params {:title ""
                                                                                            :facts [{:key ""
                                                                                                     :value ""}]
                                                                                            :items [{:title ""
                                                                                                     :subtitle ""
                                                                                                     :text ""
                                                                                                     :image {:url ""
                                                                                                             :alt ""
                                                                                                             :tap {:type ""
                                                                                                                   :title ""
                                                                                                                   :image ""
                                                                                                                   :imageAltText ""
                                                                                                                   :text ""
                                                                                                                   :displayText ""
                                                                                                                   :value {}
                                                                                                                   :channelData {}}}
                                                                                                     :price ""
                                                                                                     :quantity ""
                                                                                                     :tap {}}]
                                                                                            :tap {}
                                                                                            :total ""
                                                                                            :tax ""
                                                                                            :vat ""
                                                                                            :buttons [{}]}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/receiptCard"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"title\": \"\",\n  \"facts\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"items\": [\n    {\n      \"title\": \"\",\n      \"subtitle\": \"\",\n      \"text\": \"\",\n      \"image\": {\n        \"url\": \"\",\n        \"alt\": \"\",\n        \"tap\": {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      },\n      \"price\": \"\",\n      \"quantity\": \"\",\n      \"tap\": {}\n    }\n  ],\n  \"tap\": {},\n  \"total\": \"\",\n  \"tax\": \"\",\n  \"vat\": \"\",\n  \"buttons\": [\n    {}\n  ]\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/receiptCard"),
    Content = new StringContent("{\n  \"title\": \"\",\n  \"facts\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"items\": [\n    {\n      \"title\": \"\",\n      \"subtitle\": \"\",\n      \"text\": \"\",\n      \"image\": {\n        \"url\": \"\",\n        \"alt\": \"\",\n        \"tap\": {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      },\n      \"price\": \"\",\n      \"quantity\": \"\",\n      \"tap\": {}\n    }\n  ],\n  \"tap\": {},\n  \"total\": \"\",\n  \"tax\": \"\",\n  \"vat\": \"\",\n  \"buttons\": [\n    {}\n  ]\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3/connectorInternals/receiptCard");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"title\": \"\",\n  \"facts\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"items\": [\n    {\n      \"title\": \"\",\n      \"subtitle\": \"\",\n      \"text\": \"\",\n      \"image\": {\n        \"url\": \"\",\n        \"alt\": \"\",\n        \"tap\": {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      },\n      \"price\": \"\",\n      \"quantity\": \"\",\n      \"tap\": {}\n    }\n  ],\n  \"tap\": {},\n  \"total\": \"\",\n  \"tax\": \"\",\n  \"vat\": \"\",\n  \"buttons\": [\n    {}\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/receiptCard"

	payload := strings.NewReader("{\n  \"title\": \"\",\n  \"facts\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"items\": [\n    {\n      \"title\": \"\",\n      \"subtitle\": \"\",\n      \"text\": \"\",\n      \"image\": {\n        \"url\": \"\",\n        \"alt\": \"\",\n        \"tap\": {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      },\n      \"price\": \"\",\n      \"quantity\": \"\",\n      \"tap\": {}\n    }\n  ],\n  \"tap\": {},\n  \"total\": \"\",\n  \"tax\": \"\",\n  \"vat\": \"\",\n  \"buttons\": [\n    {}\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/connectorInternals/receiptCard HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 600

{
  "title": "",
  "facts": [
    {
      "key": "",
      "value": ""
    }
  ],
  "items": [
    {
      "title": "",
      "subtitle": "",
      "text": "",
      "image": {
        "url": "",
        "alt": "",
        "tap": {
          "type": "",
          "title": "",
          "image": "",
          "imageAltText": "",
          "text": "",
          "displayText": "",
          "value": {},
          "channelData": {}
        }
      },
      "price": "",
      "quantity": "",
      "tap": {}
    }
  ],
  "tap": {},
  "total": "",
  "tax": "",
  "vat": "",
  "buttons": [
    {}
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/receiptCard")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"title\": \"\",\n  \"facts\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"items\": [\n    {\n      \"title\": \"\",\n      \"subtitle\": \"\",\n      \"text\": \"\",\n      \"image\": {\n        \"url\": \"\",\n        \"alt\": \"\",\n        \"tap\": {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      },\n      \"price\": \"\",\n      \"quantity\": \"\",\n      \"tap\": {}\n    }\n  ],\n  \"tap\": {},\n  \"total\": \"\",\n  \"tax\": \"\",\n  \"vat\": \"\",\n  \"buttons\": [\n    {}\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/receiptCard"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"title\": \"\",\n  \"facts\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"items\": [\n    {\n      \"title\": \"\",\n      \"subtitle\": \"\",\n      \"text\": \"\",\n      \"image\": {\n        \"url\": \"\",\n        \"alt\": \"\",\n        \"tap\": {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      },\n      \"price\": \"\",\n      \"quantity\": \"\",\n      \"tap\": {}\n    }\n  ],\n  \"tap\": {},\n  \"total\": \"\",\n  \"tax\": \"\",\n  \"vat\": \"\",\n  \"buttons\": [\n    {}\n  ]\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"title\": \"\",\n  \"facts\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"items\": [\n    {\n      \"title\": \"\",\n      \"subtitle\": \"\",\n      \"text\": \"\",\n      \"image\": {\n        \"url\": \"\",\n        \"alt\": \"\",\n        \"tap\": {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      },\n      \"price\": \"\",\n      \"quantity\": \"\",\n      \"tap\": {}\n    }\n  ],\n  \"tap\": {},\n  \"total\": \"\",\n  \"tax\": \"\",\n  \"vat\": \"\",\n  \"buttons\": [\n    {}\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/receiptCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/receiptCard")
  .header("content-type", "application/json")
  .body("{\n  \"title\": \"\",\n  \"facts\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"items\": [\n    {\n      \"title\": \"\",\n      \"subtitle\": \"\",\n      \"text\": \"\",\n      \"image\": {\n        \"url\": \"\",\n        \"alt\": \"\",\n        \"tap\": {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      },\n      \"price\": \"\",\n      \"quantity\": \"\",\n      \"tap\": {}\n    }\n  ],\n  \"tap\": {},\n  \"total\": \"\",\n  \"tax\": \"\",\n  \"vat\": \"\",\n  \"buttons\": [\n    {}\n  ]\n}")
  .asString();
const data = JSON.stringify({
  title: '',
  facts: [
    {
      key: '',
      value: ''
    }
  ],
  items: [
    {
      title: '',
      subtitle: '',
      text: '',
      image: {
        url: '',
        alt: '',
        tap: {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      },
      price: '',
      quantity: '',
      tap: {}
    }
  ],
  tap: {},
  total: '',
  tax: '',
  vat: '',
  buttons: [
    {}
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/receiptCard');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/receiptCard',
  headers: {'content-type': 'application/json'},
  data: {
    title: '',
    facts: [{key: '', value: ''}],
    items: [
      {
        title: '',
        subtitle: '',
        text: '',
        image: {
          url: '',
          alt: '',
          tap: {
            type: '',
            title: '',
            image: '',
            imageAltText: '',
            text: '',
            displayText: '',
            value: {},
            channelData: {}
          }
        },
        price: '',
        quantity: '',
        tap: {}
      }
    ],
    tap: {},
    total: '',
    tax: '',
    vat: '',
    buttons: [{}]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/receiptCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"title":"","facts":[{"key":"","value":""}],"items":[{"title":"","subtitle":"","text":"","image":{"url":"","alt":"","tap":{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}},"price":"","quantity":"","tap":{}}],"tap":{},"total":"","tax":"","vat":"","buttons":[{}]}'
};

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}}/v3/connectorInternals/receiptCard',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "title": "",\n  "facts": [\n    {\n      "key": "",\n      "value": ""\n    }\n  ],\n  "items": [\n    {\n      "title": "",\n      "subtitle": "",\n      "text": "",\n      "image": {\n        "url": "",\n        "alt": "",\n        "tap": {\n          "type": "",\n          "title": "",\n          "image": "",\n          "imageAltText": "",\n          "text": "",\n          "displayText": "",\n          "value": {},\n          "channelData": {}\n        }\n      },\n      "price": "",\n      "quantity": "",\n      "tap": {}\n    }\n  ],\n  "tap": {},\n  "total": "",\n  "tax": "",\n  "vat": "",\n  "buttons": [\n    {}\n  ]\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"title\": \"\",\n  \"facts\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"items\": [\n    {\n      \"title\": \"\",\n      \"subtitle\": \"\",\n      \"text\": \"\",\n      \"image\": {\n        \"url\": \"\",\n        \"alt\": \"\",\n        \"tap\": {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      },\n      \"price\": \"\",\n      \"quantity\": \"\",\n      \"tap\": {}\n    }\n  ],\n  \"tap\": {},\n  \"total\": \"\",\n  \"tax\": \"\",\n  \"vat\": \"\",\n  \"buttons\": [\n    {}\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/receiptCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/receiptCard',
  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({
  title: '',
  facts: [{key: '', value: ''}],
  items: [
    {
      title: '',
      subtitle: '',
      text: '',
      image: {
        url: '',
        alt: '',
        tap: {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      },
      price: '',
      quantity: '',
      tap: {}
    }
  ],
  tap: {},
  total: '',
  tax: '',
  vat: '',
  buttons: [{}]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/receiptCard',
  headers: {'content-type': 'application/json'},
  body: {
    title: '',
    facts: [{key: '', value: ''}],
    items: [
      {
        title: '',
        subtitle: '',
        text: '',
        image: {
          url: '',
          alt: '',
          tap: {
            type: '',
            title: '',
            image: '',
            imageAltText: '',
            text: '',
            displayText: '',
            value: {},
            channelData: {}
          }
        },
        price: '',
        quantity: '',
        tap: {}
      }
    ],
    tap: {},
    total: '',
    tax: '',
    vat: '',
    buttons: [{}]
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/receiptCard');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  title: '',
  facts: [
    {
      key: '',
      value: ''
    }
  ],
  items: [
    {
      title: '',
      subtitle: '',
      text: '',
      image: {
        url: '',
        alt: '',
        tap: {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      },
      price: '',
      quantity: '',
      tap: {}
    }
  ],
  tap: {},
  total: '',
  tax: '',
  vat: '',
  buttons: [
    {}
  ]
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/receiptCard',
  headers: {'content-type': 'application/json'},
  data: {
    title: '',
    facts: [{key: '', value: ''}],
    items: [
      {
        title: '',
        subtitle: '',
        text: '',
        image: {
          url: '',
          alt: '',
          tap: {
            type: '',
            title: '',
            image: '',
            imageAltText: '',
            text: '',
            displayText: '',
            value: {},
            channelData: {}
          }
        },
        price: '',
        quantity: '',
        tap: {}
      }
    ],
    tap: {},
    total: '',
    tax: '',
    vat: '',
    buttons: [{}]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/connectorInternals/receiptCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"title":"","facts":[{"key":"","value":""}],"items":[{"title":"","subtitle":"","text":"","image":{"url":"","alt":"","tap":{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}},"price":"","quantity":"","tap":{}}],"tap":{},"total":"","tax":"","vat":"","buttons":[{}]}'
};

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 = @{ @"title": @"",
                              @"facts": @[ @{ @"key": @"", @"value": @"" } ],
                              @"items": @[ @{ @"title": @"", @"subtitle": @"", @"text": @"", @"image": @{ @"url": @"", @"alt": @"", @"tap": @{ @"type": @"", @"title": @"", @"image": @"", @"imageAltText": @"", @"text": @"", @"displayText": @"", @"value": @{  }, @"channelData": @{  } } }, @"price": @"", @"quantity": @"", @"tap": @{  } } ],
                              @"tap": @{  },
                              @"total": @"",
                              @"tax": @"",
                              @"vat": @"",
                              @"buttons": @[ @{  } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/connectorInternals/receiptCard"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/receiptCard" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"title\": \"\",\n  \"facts\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"items\": [\n    {\n      \"title\": \"\",\n      \"subtitle\": \"\",\n      \"text\": \"\",\n      \"image\": {\n        \"url\": \"\",\n        \"alt\": \"\",\n        \"tap\": {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      },\n      \"price\": \"\",\n      \"quantity\": \"\",\n      \"tap\": {}\n    }\n  ],\n  \"tap\": {},\n  \"total\": \"\",\n  \"tax\": \"\",\n  \"vat\": \"\",\n  \"buttons\": [\n    {}\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/receiptCard",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'title' => '',
    'facts' => [
        [
                'key' => '',
                'value' => ''
        ]
    ],
    'items' => [
        [
                'title' => '',
                'subtitle' => '',
                'text' => '',
                'image' => [
                                'url' => '',
                                'alt' => '',
                                'tap' => [
                                                                'type' => '',
                                                                'title' => '',
                                                                'image' => '',
                                                                'imageAltText' => '',
                                                                'text' => '',
                                                                'displayText' => '',
                                                                'value' => [
                                                                                                                                
                                                                ],
                                                                'channelData' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'price' => '',
                'quantity' => '',
                'tap' => [
                                
                ]
        ]
    ],
    'tap' => [
        
    ],
    'total' => '',
    'tax' => '',
    'vat' => '',
    'buttons' => [
        [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/receiptCard', [
  'body' => '{
  "title": "",
  "facts": [
    {
      "key": "",
      "value": ""
    }
  ],
  "items": [
    {
      "title": "",
      "subtitle": "",
      "text": "",
      "image": {
        "url": "",
        "alt": "",
        "tap": {
          "type": "",
          "title": "",
          "image": "",
          "imageAltText": "",
          "text": "",
          "displayText": "",
          "value": {},
          "channelData": {}
        }
      },
      "price": "",
      "quantity": "",
      "tap": {}
    }
  ],
  "tap": {},
  "total": "",
  "tax": "",
  "vat": "",
  "buttons": [
    {}
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/receiptCard');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'title' => '',
  'facts' => [
    [
        'key' => '',
        'value' => ''
    ]
  ],
  'items' => [
    [
        'title' => '',
        'subtitle' => '',
        'text' => '',
        'image' => [
                'url' => '',
                'alt' => '',
                'tap' => [
                                'type' => '',
                                'title' => '',
                                'image' => '',
                                'imageAltText' => '',
                                'text' => '',
                                'displayText' => '',
                                'value' => [
                                                                
                                ],
                                'channelData' => [
                                                                
                                ]
                ]
        ],
        'price' => '',
        'quantity' => '',
        'tap' => [
                
        ]
    ]
  ],
  'tap' => [
    
  ],
  'total' => '',
  'tax' => '',
  'vat' => '',
  'buttons' => [
    [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'title' => '',
  'facts' => [
    [
        'key' => '',
        'value' => ''
    ]
  ],
  'items' => [
    [
        'title' => '',
        'subtitle' => '',
        'text' => '',
        'image' => [
                'url' => '',
                'alt' => '',
                'tap' => [
                                'type' => '',
                                'title' => '',
                                'image' => '',
                                'imageAltText' => '',
                                'text' => '',
                                'displayText' => '',
                                'value' => [
                                                                
                                ],
                                'channelData' => [
                                                                
                                ]
                ]
        ],
        'price' => '',
        'quantity' => '',
        'tap' => [
                
        ]
    ]
  ],
  'tap' => [
    
  ],
  'total' => '',
  'tax' => '',
  'vat' => '',
  'buttons' => [
    [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/receiptCard');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/receiptCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "title": "",
  "facts": [
    {
      "key": "",
      "value": ""
    }
  ],
  "items": [
    {
      "title": "",
      "subtitle": "",
      "text": "",
      "image": {
        "url": "",
        "alt": "",
        "tap": {
          "type": "",
          "title": "",
          "image": "",
          "imageAltText": "",
          "text": "",
          "displayText": "",
          "value": {},
          "channelData": {}
        }
      },
      "price": "",
      "quantity": "",
      "tap": {}
    }
  ],
  "tap": {},
  "total": "",
  "tax": "",
  "vat": "",
  "buttons": [
    {}
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/receiptCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "title": "",
  "facts": [
    {
      "key": "",
      "value": ""
    }
  ],
  "items": [
    {
      "title": "",
      "subtitle": "",
      "text": "",
      "image": {
        "url": "",
        "alt": "",
        "tap": {
          "type": "",
          "title": "",
          "image": "",
          "imageAltText": "",
          "text": "",
          "displayText": "",
          "value": {},
          "channelData": {}
        }
      },
      "price": "",
      "quantity": "",
      "tap": {}
    }
  ],
  "tap": {},
  "total": "",
  "tax": "",
  "vat": "",
  "buttons": [
    {}
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"title\": \"\",\n  \"facts\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"items\": [\n    {\n      \"title\": \"\",\n      \"subtitle\": \"\",\n      \"text\": \"\",\n      \"image\": {\n        \"url\": \"\",\n        \"alt\": \"\",\n        \"tap\": {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      },\n      \"price\": \"\",\n      \"quantity\": \"\",\n      \"tap\": {}\n    }\n  ],\n  \"tap\": {},\n  \"total\": \"\",\n  \"tax\": \"\",\n  \"vat\": \"\",\n  \"buttons\": [\n    {}\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/connectorInternals/receiptCard", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/connectorInternals/receiptCard"

payload = {
    "title": "",
    "facts": [
        {
            "key": "",
            "value": ""
        }
    ],
    "items": [
        {
            "title": "",
            "subtitle": "",
            "text": "",
            "image": {
                "url": "",
                "alt": "",
                "tap": {
                    "type": "",
                    "title": "",
                    "image": "",
                    "imageAltText": "",
                    "text": "",
                    "displayText": "",
                    "value": {},
                    "channelData": {}
                }
            },
            "price": "",
            "quantity": "",
            "tap": {}
        }
    ],
    "tap": {},
    "total": "",
    "tax": "",
    "vat": "",
    "buttons": [{}]
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/connectorInternals/receiptCard"

payload <- "{\n  \"title\": \"\",\n  \"facts\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"items\": [\n    {\n      \"title\": \"\",\n      \"subtitle\": \"\",\n      \"text\": \"\",\n      \"image\": {\n        \"url\": \"\",\n        \"alt\": \"\",\n        \"tap\": {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      },\n      \"price\": \"\",\n      \"quantity\": \"\",\n      \"tap\": {}\n    }\n  ],\n  \"tap\": {},\n  \"total\": \"\",\n  \"tax\": \"\",\n  \"vat\": \"\",\n  \"buttons\": [\n    {}\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/connectorInternals/receiptCard")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"title\": \"\",\n  \"facts\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"items\": [\n    {\n      \"title\": \"\",\n      \"subtitle\": \"\",\n      \"text\": \"\",\n      \"image\": {\n        \"url\": \"\",\n        \"alt\": \"\",\n        \"tap\": {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      },\n      \"price\": \"\",\n      \"quantity\": \"\",\n      \"tap\": {}\n    }\n  ],\n  \"tap\": {},\n  \"total\": \"\",\n  \"tax\": \"\",\n  \"vat\": \"\",\n  \"buttons\": [\n    {}\n  ]\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/connectorInternals/receiptCard') do |req|
  req.body = "{\n  \"title\": \"\",\n  \"facts\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"items\": [\n    {\n      \"title\": \"\",\n      \"subtitle\": \"\",\n      \"text\": \"\",\n      \"image\": {\n        \"url\": \"\",\n        \"alt\": \"\",\n        \"tap\": {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      },\n      \"price\": \"\",\n      \"quantity\": \"\",\n      \"tap\": {}\n    }\n  ],\n  \"tap\": {},\n  \"total\": \"\",\n  \"tax\": \"\",\n  \"vat\": \"\",\n  \"buttons\": [\n    {}\n  ]\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/connectorInternals/receiptCard";

    let payload = json!({
        "title": "",
        "facts": (
            json!({
                "key": "",
                "value": ""
            })
        ),
        "items": (
            json!({
                "title": "",
                "subtitle": "",
                "text": "",
                "image": json!({
                    "url": "",
                    "alt": "",
                    "tap": json!({
                        "type": "",
                        "title": "",
                        "image": "",
                        "imageAltText": "",
                        "text": "",
                        "displayText": "",
                        "value": json!({}),
                        "channelData": json!({})
                    })
                }),
                "price": "",
                "quantity": "",
                "tap": json!({})
            })
        ),
        "tap": json!({}),
        "total": "",
        "tax": "",
        "vat": "",
        "buttons": (json!({}))
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/receiptCard \
  --header 'content-type: application/json' \
  --data '{
  "title": "",
  "facts": [
    {
      "key": "",
      "value": ""
    }
  ],
  "items": [
    {
      "title": "",
      "subtitle": "",
      "text": "",
      "image": {
        "url": "",
        "alt": "",
        "tap": {
          "type": "",
          "title": "",
          "image": "",
          "imageAltText": "",
          "text": "",
          "displayText": "",
          "value": {},
          "channelData": {}
        }
      },
      "price": "",
      "quantity": "",
      "tap": {}
    }
  ],
  "tap": {},
  "total": "",
  "tax": "",
  "vat": "",
  "buttons": [
    {}
  ]
}'
echo '{
  "title": "",
  "facts": [
    {
      "key": "",
      "value": ""
    }
  ],
  "items": [
    {
      "title": "",
      "subtitle": "",
      "text": "",
      "image": {
        "url": "",
        "alt": "",
        "tap": {
          "type": "",
          "title": "",
          "image": "",
          "imageAltText": "",
          "text": "",
          "displayText": "",
          "value": {},
          "channelData": {}
        }
      },
      "price": "",
      "quantity": "",
      "tap": {}
    }
  ],
  "tap": {},
  "total": "",
  "tax": "",
  "vat": "",
  "buttons": [
    {}
  ]
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/receiptCard \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "title": "",\n  "facts": [\n    {\n      "key": "",\n      "value": ""\n    }\n  ],\n  "items": [\n    {\n      "title": "",\n      "subtitle": "",\n      "text": "",\n      "image": {\n        "url": "",\n        "alt": "",\n        "tap": {\n          "type": "",\n          "title": "",\n          "image": "",\n          "imageAltText": "",\n          "text": "",\n          "displayText": "",\n          "value": {},\n          "channelData": {}\n        }\n      },\n      "price": "",\n      "quantity": "",\n      "tap": {}\n    }\n  ],\n  "tap": {},\n  "total": "",\n  "tax": "",\n  "vat": "",\n  "buttons": [\n    {}\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/receiptCard
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "title": "",
  "facts": [
    [
      "key": "",
      "value": ""
    ]
  ],
  "items": [
    [
      "title": "",
      "subtitle": "",
      "text": "",
      "image": [
        "url": "",
        "alt": "",
        "tap": [
          "type": "",
          "title": "",
          "image": "",
          "imageAltText": "",
          "text": "",
          "displayText": "",
          "value": [],
          "channelData": []
        ]
      ],
      "price": "",
      "quantity": "",
      "tap": []
    ]
  ],
  "tap": [],
  "total": "",
  "tax": "",
  "vat": "",
  "buttons": [[]]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/connectorInternals/receiptCard")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST PostResourceResponse
{{baseUrl}}/v3/connectorInternals/resourceResponse
BODY json

{
  "id": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/resourceResponse");

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  \"id\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/connectorInternals/resourceResponse" {:content-type :json
                                                                                   :form-params {:id ""}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/resourceResponse"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"id\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/resourceResponse"),
    Content = new StringContent("{\n  \"id\": \"\"\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}}/v3/connectorInternals/resourceResponse");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/resourceResponse"

	payload := strings.NewReader("{\n  \"id\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/connectorInternals/resourceResponse HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 14

{
  "id": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/resourceResponse")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/resourceResponse"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"id\": \"\"\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  \"id\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/resourceResponse")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/resourceResponse")
  .header("content-type", "application/json")
  .body("{\n  \"id\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  id: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/resourceResponse');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/resourceResponse',
  headers: {'content-type': 'application/json'},
  data: {id: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/resourceResponse';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"id":""}'
};

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}}/v3/connectorInternals/resourceResponse',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"id\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/resourceResponse")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/resourceResponse',
  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({id: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/resourceResponse',
  headers: {'content-type': 'application/json'},
  body: {id: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/resourceResponse');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/resourceResponse',
  headers: {'content-type': 'application/json'},
  data: {id: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/connectorInternals/resourceResponse';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"id":""}'
};

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 = @{ @"id": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/connectorInternals/resourceResponse"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/resourceResponse" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"id\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/resourceResponse",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'id' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/resourceResponse', [
  'body' => '{
  "id": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/resourceResponse');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/resourceResponse');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/resourceResponse' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/resourceResponse' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/connectorInternals/resourceResponse", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/connectorInternals/resourceResponse"

payload = { "id": "" }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/connectorInternals/resourceResponse"

payload <- "{\n  \"id\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/connectorInternals/resourceResponse")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/connectorInternals/resourceResponse') do |req|
  req.body = "{\n  \"id\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/connectorInternals/resourceResponse";

    let payload = json!({"id": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/resourceResponse \
  --header 'content-type: application/json' \
  --data '{
  "id": ""
}'
echo '{
  "id": ""
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/resourceResponse \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": ""\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/resourceResponse
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["id": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/connectorInternals/resourceResponse")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST PostSearchInvokeResponse
{{baseUrl}}/v3/connectorInternals/searchInvokeResponse
BODY json

{
  "statusCode": 0,
  "type": "",
  "value": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/searchInvokeResponse");

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  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/connectorInternals/searchInvokeResponse" {:content-type :json
                                                                                       :form-params {:statusCode 0
                                                                                                     :type ""
                                                                                                     :value {}}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/searchInvokeResponse"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/searchInvokeResponse"),
    Content = new StringContent("{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\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}}/v3/connectorInternals/searchInvokeResponse");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/searchInvokeResponse"

	payload := strings.NewReader("{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/connectorInternals/searchInvokeResponse HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 50

{
  "statusCode": 0,
  "type": "",
  "value": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/searchInvokeResponse")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/searchInvokeResponse"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\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  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/searchInvokeResponse")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/searchInvokeResponse")
  .header("content-type", "application/json")
  .body("{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}")
  .asString();
const data = JSON.stringify({
  statusCode: 0,
  type: '',
  value: {}
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/searchInvokeResponse');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/searchInvokeResponse',
  headers: {'content-type': 'application/json'},
  data: {statusCode: 0, type: '', value: {}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/searchInvokeResponse';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"statusCode":0,"type":"","value":{}}'
};

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}}/v3/connectorInternals/searchInvokeResponse',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "statusCode": 0,\n  "type": "",\n  "value": {}\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/searchInvokeResponse")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/searchInvokeResponse',
  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({statusCode: 0, type: '', value: {}}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/searchInvokeResponse',
  headers: {'content-type': 'application/json'},
  body: {statusCode: 0, type: '', value: {}},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/searchInvokeResponse');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  statusCode: 0,
  type: '',
  value: {}
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/searchInvokeResponse',
  headers: {'content-type': 'application/json'},
  data: {statusCode: 0, type: '', value: {}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/connectorInternals/searchInvokeResponse';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"statusCode":0,"type":"","value":{}}'
};

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 = @{ @"statusCode": @0,
                              @"type": @"",
                              @"value": @{  } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/connectorInternals/searchInvokeResponse"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/searchInvokeResponse" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/searchInvokeResponse",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'statusCode' => 0,
    'type' => '',
    'value' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/searchInvokeResponse', [
  'body' => '{
  "statusCode": 0,
  "type": "",
  "value": {}
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/searchInvokeResponse');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'statusCode' => 0,
  'type' => '',
  'value' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'statusCode' => 0,
  'type' => '',
  'value' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/searchInvokeResponse');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/searchInvokeResponse' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "statusCode": 0,
  "type": "",
  "value": {}
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/searchInvokeResponse' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "statusCode": 0,
  "type": "",
  "value": {}
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/connectorInternals/searchInvokeResponse", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/connectorInternals/searchInvokeResponse"

payload = {
    "statusCode": 0,
    "type": "",
    "value": {}
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/connectorInternals/searchInvokeResponse"

payload <- "{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/connectorInternals/searchInvokeResponse")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/connectorInternals/searchInvokeResponse') do |req|
  req.body = "{\n  \"statusCode\": 0,\n  \"type\": \"\",\n  \"value\": {}\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/connectorInternals/searchInvokeResponse";

    let payload = json!({
        "statusCode": 0,
        "type": "",
        "value": json!({})
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/searchInvokeResponse \
  --header 'content-type: application/json' \
  --data '{
  "statusCode": 0,
  "type": "",
  "value": {}
}'
echo '{
  "statusCode": 0,
  "type": "",
  "value": {}
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/searchInvokeResponse \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "statusCode": 0,\n  "type": "",\n  "value": {}\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/searchInvokeResponse
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "statusCode": 0,
  "type": "",
  "value": []
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/connectorInternals/searchInvokeResponse")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST PostSearchInvokeValue
{{baseUrl}}/v3/connectorInternals/searchInvokeValue
BODY json

{
  "kind": "",
  "queryText": "",
  "queryOptions": {},
  "context": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/searchInvokeValue");

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  \"kind\": \"\",\n  \"queryText\": \"\",\n  \"queryOptions\": {},\n  \"context\": {}\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/connectorInternals/searchInvokeValue" {:content-type :json
                                                                                    :form-params {:kind ""
                                                                                                  :queryText ""
                                                                                                  :queryOptions {}
                                                                                                  :context {}}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/searchInvokeValue"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"kind\": \"\",\n  \"queryText\": \"\",\n  \"queryOptions\": {},\n  \"context\": {}\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/searchInvokeValue"),
    Content = new StringContent("{\n  \"kind\": \"\",\n  \"queryText\": \"\",\n  \"queryOptions\": {},\n  \"context\": {}\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}}/v3/connectorInternals/searchInvokeValue");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"kind\": \"\",\n  \"queryText\": \"\",\n  \"queryOptions\": {},\n  \"context\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/searchInvokeValue"

	payload := strings.NewReader("{\n  \"kind\": \"\",\n  \"queryText\": \"\",\n  \"queryOptions\": {},\n  \"context\": {}\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/connectorInternals/searchInvokeValue HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 74

{
  "kind": "",
  "queryText": "",
  "queryOptions": {},
  "context": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/searchInvokeValue")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"kind\": \"\",\n  \"queryText\": \"\",\n  \"queryOptions\": {},\n  \"context\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/searchInvokeValue"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"kind\": \"\",\n  \"queryText\": \"\",\n  \"queryOptions\": {},\n  \"context\": {}\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  \"kind\": \"\",\n  \"queryText\": \"\",\n  \"queryOptions\": {},\n  \"context\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/searchInvokeValue")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/searchInvokeValue")
  .header("content-type", "application/json")
  .body("{\n  \"kind\": \"\",\n  \"queryText\": \"\",\n  \"queryOptions\": {},\n  \"context\": {}\n}")
  .asString();
const data = JSON.stringify({
  kind: '',
  queryText: '',
  queryOptions: {},
  context: {}
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/searchInvokeValue');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/searchInvokeValue',
  headers: {'content-type': 'application/json'},
  data: {kind: '', queryText: '', queryOptions: {}, context: {}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/searchInvokeValue';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"kind":"","queryText":"","queryOptions":{},"context":{}}'
};

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}}/v3/connectorInternals/searchInvokeValue',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "kind": "",\n  "queryText": "",\n  "queryOptions": {},\n  "context": {}\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"kind\": \"\",\n  \"queryText\": \"\",\n  \"queryOptions\": {},\n  \"context\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/searchInvokeValue")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/searchInvokeValue',
  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({kind: '', queryText: '', queryOptions: {}, context: {}}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/searchInvokeValue',
  headers: {'content-type': 'application/json'},
  body: {kind: '', queryText: '', queryOptions: {}, context: {}},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/searchInvokeValue');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  kind: '',
  queryText: '',
  queryOptions: {},
  context: {}
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/searchInvokeValue',
  headers: {'content-type': 'application/json'},
  data: {kind: '', queryText: '', queryOptions: {}, context: {}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/connectorInternals/searchInvokeValue';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"kind":"","queryText":"","queryOptions":{},"context":{}}'
};

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 = @{ @"kind": @"",
                              @"queryText": @"",
                              @"queryOptions": @{  },
                              @"context": @{  } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/connectorInternals/searchInvokeValue"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/searchInvokeValue" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"kind\": \"\",\n  \"queryText\": \"\",\n  \"queryOptions\": {},\n  \"context\": {}\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/searchInvokeValue",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'kind' => '',
    'queryText' => '',
    'queryOptions' => [
        
    ],
    'context' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/searchInvokeValue', [
  'body' => '{
  "kind": "",
  "queryText": "",
  "queryOptions": {},
  "context": {}
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/searchInvokeValue');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'kind' => '',
  'queryText' => '',
  'queryOptions' => [
    
  ],
  'context' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'kind' => '',
  'queryText' => '',
  'queryOptions' => [
    
  ],
  'context' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/searchInvokeValue');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/searchInvokeValue' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "kind": "",
  "queryText": "",
  "queryOptions": {},
  "context": {}
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/searchInvokeValue' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "kind": "",
  "queryText": "",
  "queryOptions": {},
  "context": {}
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"kind\": \"\",\n  \"queryText\": \"\",\n  \"queryOptions\": {},\n  \"context\": {}\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/connectorInternals/searchInvokeValue", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/connectorInternals/searchInvokeValue"

payload = {
    "kind": "",
    "queryText": "",
    "queryOptions": {},
    "context": {}
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/connectorInternals/searchInvokeValue"

payload <- "{\n  \"kind\": \"\",\n  \"queryText\": \"\",\n  \"queryOptions\": {},\n  \"context\": {}\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/connectorInternals/searchInvokeValue")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"kind\": \"\",\n  \"queryText\": \"\",\n  \"queryOptions\": {},\n  \"context\": {}\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/connectorInternals/searchInvokeValue') do |req|
  req.body = "{\n  \"kind\": \"\",\n  \"queryText\": \"\",\n  \"queryOptions\": {},\n  \"context\": {}\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/connectorInternals/searchInvokeValue";

    let payload = json!({
        "kind": "",
        "queryText": "",
        "queryOptions": json!({}),
        "context": json!({})
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/searchInvokeValue \
  --header 'content-type: application/json' \
  --data '{
  "kind": "",
  "queryText": "",
  "queryOptions": {},
  "context": {}
}'
echo '{
  "kind": "",
  "queryText": "",
  "queryOptions": {},
  "context": {}
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/searchInvokeValue \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "kind": "",\n  "queryText": "",\n  "queryOptions": {},\n  "context": {}\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/searchInvokeValue
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "kind": "",
  "queryText": "",
  "queryOptions": [],
  "context": []
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/connectorInternals/searchInvokeValue")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST PostSigninCard
{{baseUrl}}/v3/connectorInternals/signinCard
BODY json

{
  "text": "",
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/signinCard");

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  \"text\": \"\",\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/connectorInternals/signinCard" {:content-type :json
                                                                             :form-params {:text ""
                                                                                           :buttons [{:type ""
                                                                                                      :title ""
                                                                                                      :image ""
                                                                                                      :imageAltText ""
                                                                                                      :text ""
                                                                                                      :displayText ""
                                                                                                      :value {}
                                                                                                      :channelData {}}]}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/signinCard"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"text\": \"\",\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/signinCard"),
    Content = new StringContent("{\n  \"text\": \"\",\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3/connectorInternals/signinCard");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"text\": \"\",\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/signinCard"

	payload := strings.NewReader("{\n  \"text\": \"\",\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/connectorInternals/signinCard HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 216

{
  "text": "",
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/signinCard")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"text\": \"\",\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/signinCard"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"text\": \"\",\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"text\": \"\",\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/signinCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/signinCard")
  .header("content-type", "application/json")
  .body("{\n  \"text\": \"\",\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  text: '',
  buttons: [
    {
      type: '',
      title: '',
      image: '',
      imageAltText: '',
      text: '',
      displayText: '',
      value: {},
      channelData: {}
    }
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/signinCard');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/signinCard',
  headers: {'content-type': 'application/json'},
  data: {
    text: '',
    buttons: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/signinCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"text":"","buttons":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}]}'
};

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}}/v3/connectorInternals/signinCard',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "text": "",\n  "buttons": [\n    {\n      "type": "",\n      "title": "",\n      "image": "",\n      "imageAltText": "",\n      "text": "",\n      "displayText": "",\n      "value": {},\n      "channelData": {}\n    }\n  ]\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"text\": \"\",\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/signinCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/signinCard',
  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({
  text: '',
  buttons: [
    {
      type: '',
      title: '',
      image: '',
      imageAltText: '',
      text: '',
      displayText: '',
      value: {},
      channelData: {}
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/signinCard',
  headers: {'content-type': 'application/json'},
  body: {
    text: '',
    buttons: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ]
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/signinCard');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  text: '',
  buttons: [
    {
      type: '',
      title: '',
      image: '',
      imageAltText: '',
      text: '',
      displayText: '',
      value: {},
      channelData: {}
    }
  ]
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/signinCard',
  headers: {'content-type': 'application/json'},
  data: {
    text: '',
    buttons: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/connectorInternals/signinCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"text":"","buttons":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}]}'
};

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 = @{ @"text": @"",
                              @"buttons": @[ @{ @"type": @"", @"title": @"", @"image": @"", @"imageAltText": @"", @"text": @"", @"displayText": @"", @"value": @{  }, @"channelData": @{  } } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/connectorInternals/signinCard"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/signinCard" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"text\": \"\",\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/signinCard",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'text' => '',
    'buttons' => [
        [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/signinCard', [
  'body' => '{
  "text": "",
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/signinCard');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'text' => '',
  'buttons' => [
    [
        'type' => '',
        'title' => '',
        'image' => '',
        'imageAltText' => '',
        'text' => '',
        'displayText' => '',
        'value' => [
                
        ],
        'channelData' => [
                
        ]
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'text' => '',
  'buttons' => [
    [
        'type' => '',
        'title' => '',
        'image' => '',
        'imageAltText' => '',
        'text' => '',
        'displayText' => '',
        'value' => [
                
        ],
        'channelData' => [
                
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/signinCard');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/signinCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "text": "",
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/signinCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "text": "",
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"text\": \"\",\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/connectorInternals/signinCard", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/connectorInternals/signinCard"

payload = {
    "text": "",
    "buttons": [
        {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
        }
    ]
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/connectorInternals/signinCard"

payload <- "{\n  \"text\": \"\",\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/connectorInternals/signinCard")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"text\": \"\",\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/connectorInternals/signinCard') do |req|
  req.body = "{\n  \"text\": \"\",\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ]\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/connectorInternals/signinCard";

    let payload = json!({
        "text": "",
        "buttons": (
            json!({
                "type": "",
                "title": "",
                "image": "",
                "imageAltText": "",
                "text": "",
                "displayText": "",
                "value": json!({}),
                "channelData": json!({})
            })
        )
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/signinCard \
  --header 'content-type: application/json' \
  --data '{
  "text": "",
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ]
}'
echo '{
  "text": "",
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ]
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/signinCard \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "text": "",\n  "buttons": [\n    {\n      "type": "",\n      "title": "",\n      "image": "",\n      "imageAltText": "",\n      "text": "",\n      "displayText": "",\n      "value": {},\n      "channelData": {}\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/signinCard
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "text": "",
  "buttons": [
    [
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": [],
      "channelData": []
    ]
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/connectorInternals/signinCard")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST PostThumbnailCard
{{baseUrl}}/v3/connectorInternals/thumbnailCard
BODY json

{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/thumbnailCard");

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  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/connectorInternals/thumbnailCard" {:content-type :json
                                                                                :form-params {:title ""
                                                                                              :subtitle ""
                                                                                              :text ""
                                                                                              :images [{:url ""
                                                                                                        :alt ""
                                                                                                        :tap {:type ""
                                                                                                              :title ""
                                                                                                              :image ""
                                                                                                              :imageAltText ""
                                                                                                              :text ""
                                                                                                              :displayText ""
                                                                                                              :value {}
                                                                                                              :channelData {}}}]
                                                                                              :buttons [{}]
                                                                                              :tap {}}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/thumbnailCard"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/thumbnailCard"),
    Content = new StringContent("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\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}}/v3/connectorInternals/thumbnailCard");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/thumbnailCard"

	payload := strings.NewReader("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/connectorInternals/thumbnailCard HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 361

{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/thumbnailCard")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/thumbnailCard"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\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  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/thumbnailCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/thumbnailCard")
  .header("content-type", "application/json")
  .body("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}")
  .asString();
const data = JSON.stringify({
  title: '',
  subtitle: '',
  text: '',
  images: [
    {
      url: '',
      alt: '',
      tap: {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    }
  ],
  buttons: [
    {}
  ],
  tap: {}
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/thumbnailCard');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/thumbnailCard',
  headers: {'content-type': 'application/json'},
  data: {
    title: '',
    subtitle: '',
    text: '',
    images: [
      {
        url: '',
        alt: '',
        tap: {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      }
    ],
    buttons: [{}],
    tap: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/thumbnailCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"title":"","subtitle":"","text":"","images":[{"url":"","alt":"","tap":{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}}],"buttons":[{}],"tap":{}}'
};

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}}/v3/connectorInternals/thumbnailCard',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "title": "",\n  "subtitle": "",\n  "text": "",\n  "images": [\n    {\n      "url": "",\n      "alt": "",\n      "tap": {\n        "type": "",\n        "title": "",\n        "image": "",\n        "imageAltText": "",\n        "text": "",\n        "displayText": "",\n        "value": {},\n        "channelData": {}\n      }\n    }\n  ],\n  "buttons": [\n    {}\n  ],\n  "tap": {}\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/thumbnailCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/thumbnailCard',
  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({
  title: '',
  subtitle: '',
  text: '',
  images: [
    {
      url: '',
      alt: '',
      tap: {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    }
  ],
  buttons: [{}],
  tap: {}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/thumbnailCard',
  headers: {'content-type': 'application/json'},
  body: {
    title: '',
    subtitle: '',
    text: '',
    images: [
      {
        url: '',
        alt: '',
        tap: {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      }
    ],
    buttons: [{}],
    tap: {}
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/thumbnailCard');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  title: '',
  subtitle: '',
  text: '',
  images: [
    {
      url: '',
      alt: '',
      tap: {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    }
  ],
  buttons: [
    {}
  ],
  tap: {}
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/thumbnailCard',
  headers: {'content-type': 'application/json'},
  data: {
    title: '',
    subtitle: '',
    text: '',
    images: [
      {
        url: '',
        alt: '',
        tap: {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      }
    ],
    buttons: [{}],
    tap: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/connectorInternals/thumbnailCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"title":"","subtitle":"","text":"","images":[{"url":"","alt":"","tap":{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}}],"buttons":[{}],"tap":{}}'
};

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 = @{ @"title": @"",
                              @"subtitle": @"",
                              @"text": @"",
                              @"images": @[ @{ @"url": @"", @"alt": @"", @"tap": @{ @"type": @"", @"title": @"", @"image": @"", @"imageAltText": @"", @"text": @"", @"displayText": @"", @"value": @{  }, @"channelData": @{  } } } ],
                              @"buttons": @[ @{  } ],
                              @"tap": @{  } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/connectorInternals/thumbnailCard"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/thumbnailCard" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/thumbnailCard",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'title' => '',
    'subtitle' => '',
    'text' => '',
    'images' => [
        [
                'url' => '',
                'alt' => '',
                'tap' => [
                                'type' => '',
                                'title' => '',
                                'image' => '',
                                'imageAltText' => '',
                                'text' => '',
                                'displayText' => '',
                                'value' => [
                                                                
                                ],
                                'channelData' => [
                                                                
                                ]
                ]
        ]
    ],
    'buttons' => [
        [
                
        ]
    ],
    'tap' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/thumbnailCard', [
  'body' => '{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/thumbnailCard');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'title' => '',
  'subtitle' => '',
  'text' => '',
  'images' => [
    [
        'url' => '',
        'alt' => '',
        'tap' => [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ]
  ],
  'buttons' => [
    [
        
    ]
  ],
  'tap' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'title' => '',
  'subtitle' => '',
  'text' => '',
  'images' => [
    [
        'url' => '',
        'alt' => '',
        'tap' => [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ]
  ],
  'buttons' => [
    [
        
    ]
  ],
  'tap' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/thumbnailCard');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/thumbnailCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/thumbnailCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/connectorInternals/thumbnailCard", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/connectorInternals/thumbnailCard"

payload = {
    "title": "",
    "subtitle": "",
    "text": "",
    "images": [
        {
            "url": "",
            "alt": "",
            "tap": {
                "type": "",
                "title": "",
                "image": "",
                "imageAltText": "",
                "text": "",
                "displayText": "",
                "value": {},
                "channelData": {}
            }
        }
    ],
    "buttons": [{}],
    "tap": {}
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/connectorInternals/thumbnailCard"

payload <- "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/connectorInternals/thumbnailCard")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/connectorInternals/thumbnailCard') do |req|
  req.body = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"images\": [\n    {\n      \"url\": \"\",\n      \"alt\": \"\",\n      \"tap\": {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    }\n  ],\n  \"buttons\": [\n    {}\n  ],\n  \"tap\": {}\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/connectorInternals/thumbnailCard";

    let payload = json!({
        "title": "",
        "subtitle": "",
        "text": "",
        "images": (
            json!({
                "url": "",
                "alt": "",
                "tap": json!({
                    "type": "",
                    "title": "",
                    "image": "",
                    "imageAltText": "",
                    "text": "",
                    "displayText": "",
                    "value": json!({}),
                    "channelData": json!({})
                })
            })
        ),
        "buttons": (json!({})),
        "tap": json!({})
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/thumbnailCard \
  --header 'content-type: application/json' \
  --data '{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}'
echo '{
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    {
      "url": "",
      "alt": "",
      "tap": {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    }
  ],
  "buttons": [
    {}
  ],
  "tap": {}
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/thumbnailCard \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "title": "",\n  "subtitle": "",\n  "text": "",\n  "images": [\n    {\n      "url": "",\n      "alt": "",\n      "tap": {\n        "type": "",\n        "title": "",\n        "image": "",\n        "imageAltText": "",\n        "text": "",\n        "displayText": "",\n        "value": {},\n        "channelData": {}\n      }\n    }\n  ],\n  "buttons": [\n    {}\n  ],\n  "tap": {}\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/thumbnailCard
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "title": "",
  "subtitle": "",
  "text": "",
  "images": [
    [
      "url": "",
      "alt": "",
      "tap": [
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": [],
        "channelData": []
      ]
    ]
  ],
  "buttons": [[]],
  "tap": []
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/connectorInternals/thumbnailCard")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST PostTokenExchangeInvokeRequest
{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest
BODY json

{
  "connectionName": "",
  "token": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest");

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  \"connectionName\": \"\",\n  \"token\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest" {:content-type :json
                                                                                             :form-params {:connectionName ""
                                                                                                           :token ""}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"connectionName\": \"\",\n  \"token\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest"),
    Content = new StringContent("{\n  \"connectionName\": \"\",\n  \"token\": \"\"\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}}/v3/connectorInternals/tokenExchangeInvokeRequest");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"connectionName\": \"\",\n  \"token\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest"

	payload := strings.NewReader("{\n  \"connectionName\": \"\",\n  \"token\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/connectorInternals/tokenExchangeInvokeRequest HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 41

{
  "connectionName": "",
  "token": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"connectionName\": \"\",\n  \"token\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"connectionName\": \"\",\n  \"token\": \"\"\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  \"connectionName\": \"\",\n  \"token\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest")
  .header("content-type", "application/json")
  .body("{\n  \"connectionName\": \"\",\n  \"token\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  connectionName: '',
  token: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest',
  headers: {'content-type': 'application/json'},
  data: {connectionName: '', token: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"connectionName":"","token":""}'
};

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}}/v3/connectorInternals/tokenExchangeInvokeRequest',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "connectionName": "",\n  "token": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"connectionName\": \"\",\n  \"token\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/tokenExchangeInvokeRequest',
  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({connectionName: '', token: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest',
  headers: {'content-type': 'application/json'},
  body: {connectionName: '', token: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  connectionName: '',
  token: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest',
  headers: {'content-type': 'application/json'},
  data: {connectionName: '', token: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"connectionName":"","token":""}'
};

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 = @{ @"connectionName": @"",
                              @"token": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"connectionName\": \"\",\n  \"token\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'connectionName' => '',
    'token' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest', [
  'body' => '{
  "connectionName": "",
  "token": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'connectionName' => '',
  'token' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'connectionName' => '',
  'token' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "connectionName": "",
  "token": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "connectionName": "",
  "token": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"connectionName\": \"\",\n  \"token\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/connectorInternals/tokenExchangeInvokeRequest", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest"

payload = {
    "connectionName": "",
    "token": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest"

payload <- "{\n  \"connectionName\": \"\",\n  \"token\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"connectionName\": \"\",\n  \"token\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/connectorInternals/tokenExchangeInvokeRequest') do |req|
  req.body = "{\n  \"connectionName\": \"\",\n  \"token\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest";

    let payload = json!({
        "connectionName": "",
        "token": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest \
  --header 'content-type: application/json' \
  --data '{
  "connectionName": "",
  "token": ""
}'
echo '{
  "connectionName": "",
  "token": ""
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "connectionName": "",\n  "token": ""\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "connectionName": "",
  "token": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeRequest")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST PostTokenExchangeInvokeResponse
{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse
BODY json

{
  "connectionName": "",
  "failureDetail": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse");

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  \"connectionName\": \"\",\n  \"failureDetail\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse" {:content-type :json
                                                                                              :form-params {:connectionName ""
                                                                                                            :failureDetail ""}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"connectionName\": \"\",\n  \"failureDetail\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse"),
    Content = new StringContent("{\n  \"connectionName\": \"\",\n  \"failureDetail\": \"\"\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}}/v3/connectorInternals/tokenExchangeInvokeResponse");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"connectionName\": \"\",\n  \"failureDetail\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse"

	payload := strings.NewReader("{\n  \"connectionName\": \"\",\n  \"failureDetail\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/connectorInternals/tokenExchangeInvokeResponse HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 49

{
  "connectionName": "",
  "failureDetail": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"connectionName\": \"\",\n  \"failureDetail\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"connectionName\": \"\",\n  \"failureDetail\": \"\"\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  \"connectionName\": \"\",\n  \"failureDetail\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse")
  .header("content-type", "application/json")
  .body("{\n  \"connectionName\": \"\",\n  \"failureDetail\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  connectionName: '',
  failureDetail: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse',
  headers: {'content-type': 'application/json'},
  data: {connectionName: '', failureDetail: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"connectionName":"","failureDetail":""}'
};

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}}/v3/connectorInternals/tokenExchangeInvokeResponse',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "connectionName": "",\n  "failureDetail": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"connectionName\": \"\",\n  \"failureDetail\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/tokenExchangeInvokeResponse',
  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({connectionName: '', failureDetail: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse',
  headers: {'content-type': 'application/json'},
  body: {connectionName: '', failureDetail: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  connectionName: '',
  failureDetail: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse',
  headers: {'content-type': 'application/json'},
  data: {connectionName: '', failureDetail: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"connectionName":"","failureDetail":""}'
};

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 = @{ @"connectionName": @"",
                              @"failureDetail": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"connectionName\": \"\",\n  \"failureDetail\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'connectionName' => '',
    'failureDetail' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse', [
  'body' => '{
  "connectionName": "",
  "failureDetail": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'connectionName' => '',
  'failureDetail' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'connectionName' => '',
  'failureDetail' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "connectionName": "",
  "failureDetail": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "connectionName": "",
  "failureDetail": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"connectionName\": \"\",\n  \"failureDetail\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/connectorInternals/tokenExchangeInvokeResponse", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse"

payload = {
    "connectionName": "",
    "failureDetail": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse"

payload <- "{\n  \"connectionName\": \"\",\n  \"failureDetail\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"connectionName\": \"\",\n  \"failureDetail\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/connectorInternals/tokenExchangeInvokeResponse') do |req|
  req.body = "{\n  \"connectionName\": \"\",\n  \"failureDetail\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse";

    let payload = json!({
        "connectionName": "",
        "failureDetail": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse \
  --header 'content-type: application/json' \
  --data '{
  "connectionName": "",
  "failureDetail": ""
}'
echo '{
  "connectionName": "",
  "failureDetail": ""
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "connectionName": "",\n  "failureDetail": ""\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "connectionName": "",
  "failureDetail": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/connectorInternals/tokenExchangeInvokeResponse")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST PostTokenExchangeResource
{{baseUrl}}/v3/connectorInternals/tokenExchangeResource
BODY json

{
  "id": "",
  "uri": "",
  "providerId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/tokenExchangeResource");

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  \"id\": \"\",\n  \"uri\": \"\",\n  \"providerId\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/connectorInternals/tokenExchangeResource" {:content-type :json
                                                                                        :form-params {:id ""
                                                                                                      :uri ""
                                                                                                      :providerId ""}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/tokenExchangeResource"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"id\": \"\",\n  \"uri\": \"\",\n  \"providerId\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/tokenExchangeResource"),
    Content = new StringContent("{\n  \"id\": \"\",\n  \"uri\": \"\",\n  \"providerId\": \"\"\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}}/v3/connectorInternals/tokenExchangeResource");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"id\": \"\",\n  \"uri\": \"\",\n  \"providerId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/tokenExchangeResource"

	payload := strings.NewReader("{\n  \"id\": \"\",\n  \"uri\": \"\",\n  \"providerId\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/connectorInternals/tokenExchangeResource HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 47

{
  "id": "",
  "uri": "",
  "providerId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/tokenExchangeResource")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"id\": \"\",\n  \"uri\": \"\",\n  \"providerId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/tokenExchangeResource"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"id\": \"\",\n  \"uri\": \"\",\n  \"providerId\": \"\"\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  \"id\": \"\",\n  \"uri\": \"\",\n  \"providerId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/tokenExchangeResource")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/tokenExchangeResource")
  .header("content-type", "application/json")
  .body("{\n  \"id\": \"\",\n  \"uri\": \"\",\n  \"providerId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  id: '',
  uri: '',
  providerId: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/tokenExchangeResource');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/tokenExchangeResource',
  headers: {'content-type': 'application/json'},
  data: {id: '', uri: '', providerId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/tokenExchangeResource';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"id":"","uri":"","providerId":""}'
};

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}}/v3/connectorInternals/tokenExchangeResource',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "id": "",\n  "uri": "",\n  "providerId": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"id\": \"\",\n  \"uri\": \"\",\n  \"providerId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/tokenExchangeResource")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/tokenExchangeResource',
  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({id: '', uri: '', providerId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/tokenExchangeResource',
  headers: {'content-type': 'application/json'},
  body: {id: '', uri: '', providerId: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/tokenExchangeResource');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  id: '',
  uri: '',
  providerId: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/tokenExchangeResource',
  headers: {'content-type': 'application/json'},
  data: {id: '', uri: '', providerId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/connectorInternals/tokenExchangeResource';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"id":"","uri":"","providerId":""}'
};

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 = @{ @"id": @"",
                              @"uri": @"",
                              @"providerId": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/connectorInternals/tokenExchangeResource"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/tokenExchangeResource" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"id\": \"\",\n  \"uri\": \"\",\n  \"providerId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/tokenExchangeResource",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'id' => '',
    'uri' => '',
    'providerId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/tokenExchangeResource', [
  'body' => '{
  "id": "",
  "uri": "",
  "providerId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/tokenExchangeResource');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'id' => '',
  'uri' => '',
  'providerId' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'id' => '',
  'uri' => '',
  'providerId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/tokenExchangeResource');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/tokenExchangeResource' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id": "",
  "uri": "",
  "providerId": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/tokenExchangeResource' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "id": "",
  "uri": "",
  "providerId": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"id\": \"\",\n  \"uri\": \"\",\n  \"providerId\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/connectorInternals/tokenExchangeResource", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/connectorInternals/tokenExchangeResource"

payload = {
    "id": "",
    "uri": "",
    "providerId": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/connectorInternals/tokenExchangeResource"

payload <- "{\n  \"id\": \"\",\n  \"uri\": \"\",\n  \"providerId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/connectorInternals/tokenExchangeResource")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"id\": \"\",\n  \"uri\": \"\",\n  \"providerId\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/connectorInternals/tokenExchangeResource') do |req|
  req.body = "{\n  \"id\": \"\",\n  \"uri\": \"\",\n  \"providerId\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/connectorInternals/tokenExchangeResource";

    let payload = json!({
        "id": "",
        "uri": "",
        "providerId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/tokenExchangeResource \
  --header 'content-type: application/json' \
  --data '{
  "id": "",
  "uri": "",
  "providerId": ""
}'
echo '{
  "id": "",
  "uri": "",
  "providerId": ""
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/tokenExchangeResource \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "id": "",\n  "uri": "",\n  "providerId": ""\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/tokenExchangeResource
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "id": "",
  "uri": "",
  "providerId": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/connectorInternals/tokenExchangeResource")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST PostTokenExchangeState
{{baseUrl}}/v3/connectorInternals/tokenExchangeState
BODY json

{
  "connectionName": "",
  "conversation": {
    "activityId": "",
    "user": {
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "bot": {},
    "conversation": {
      "isGroup": false,
      "conversationType": "",
      "tenantId": "",
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "relatesTo": {},
  "msAppId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/tokenExchangeState");

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  \"connectionName\": \"\",\n  \"conversation\": {\n    \"activityId\": \"\",\n    \"user\": {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"bot\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"relatesTo\": {},\n  \"msAppId\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/connectorInternals/tokenExchangeState" {:content-type :json
                                                                                     :form-params {:connectionName ""
                                                                                                   :conversation {:activityId ""
                                                                                                                  :user {:id ""
                                                                                                                         :name ""
                                                                                                                         :aadObjectId ""
                                                                                                                         :role ""}
                                                                                                                  :bot {}
                                                                                                                  :conversation {:isGroup false
                                                                                                                                 :conversationType ""
                                                                                                                                 :tenantId ""
                                                                                                                                 :id ""
                                                                                                                                 :name ""
                                                                                                                                 :aadObjectId ""
                                                                                                                                 :role ""}
                                                                                                                  :channelId ""
                                                                                                                  :serviceUrl ""
                                                                                                                  :locale ""}
                                                                                                   :relatesTo {}
                                                                                                   :msAppId ""}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/tokenExchangeState"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"connectionName\": \"\",\n  \"conversation\": {\n    \"activityId\": \"\",\n    \"user\": {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"bot\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"relatesTo\": {},\n  \"msAppId\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/tokenExchangeState"),
    Content = new StringContent("{\n  \"connectionName\": \"\",\n  \"conversation\": {\n    \"activityId\": \"\",\n    \"user\": {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"bot\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"relatesTo\": {},\n  \"msAppId\": \"\"\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}}/v3/connectorInternals/tokenExchangeState");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"connectionName\": \"\",\n  \"conversation\": {\n    \"activityId\": \"\",\n    \"user\": {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"bot\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"relatesTo\": {},\n  \"msAppId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/tokenExchangeState"

	payload := strings.NewReader("{\n  \"connectionName\": \"\",\n  \"conversation\": {\n    \"activityId\": \"\",\n    \"user\": {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"bot\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"relatesTo\": {},\n  \"msAppId\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/connectorInternals/tokenExchangeState HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 462

{
  "connectionName": "",
  "conversation": {
    "activityId": "",
    "user": {
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "bot": {},
    "conversation": {
      "isGroup": false,
      "conversationType": "",
      "tenantId": "",
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "relatesTo": {},
  "msAppId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/tokenExchangeState")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"connectionName\": \"\",\n  \"conversation\": {\n    \"activityId\": \"\",\n    \"user\": {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"bot\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"relatesTo\": {},\n  \"msAppId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/tokenExchangeState"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"connectionName\": \"\",\n  \"conversation\": {\n    \"activityId\": \"\",\n    \"user\": {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"bot\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"relatesTo\": {},\n  \"msAppId\": \"\"\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  \"connectionName\": \"\",\n  \"conversation\": {\n    \"activityId\": \"\",\n    \"user\": {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"bot\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"relatesTo\": {},\n  \"msAppId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/tokenExchangeState")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/tokenExchangeState")
  .header("content-type", "application/json")
  .body("{\n  \"connectionName\": \"\",\n  \"conversation\": {\n    \"activityId\": \"\",\n    \"user\": {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"bot\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"relatesTo\": {},\n  \"msAppId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  connectionName: '',
  conversation: {
    activityId: '',
    user: {
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    bot: {},
    conversation: {
      isGroup: false,
      conversationType: '',
      tenantId: '',
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    channelId: '',
    serviceUrl: '',
    locale: ''
  },
  relatesTo: {},
  msAppId: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/tokenExchangeState');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/tokenExchangeState',
  headers: {'content-type': 'application/json'},
  data: {
    connectionName: '',
    conversation: {
      activityId: '',
      user: {id: '', name: '', aadObjectId: '', role: ''},
      bot: {},
      conversation: {
        isGroup: false,
        conversationType: '',
        tenantId: '',
        id: '',
        name: '',
        aadObjectId: '',
        role: ''
      },
      channelId: '',
      serviceUrl: '',
      locale: ''
    },
    relatesTo: {},
    msAppId: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/tokenExchangeState';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"connectionName":"","conversation":{"activityId":"","user":{"id":"","name":"","aadObjectId":"","role":""},"bot":{},"conversation":{"isGroup":false,"conversationType":"","tenantId":"","id":"","name":"","aadObjectId":"","role":""},"channelId":"","serviceUrl":"","locale":""},"relatesTo":{},"msAppId":""}'
};

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}}/v3/connectorInternals/tokenExchangeState',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "connectionName": "",\n  "conversation": {\n    "activityId": "",\n    "user": {\n      "id": "",\n      "name": "",\n      "aadObjectId": "",\n      "role": ""\n    },\n    "bot": {},\n    "conversation": {\n      "isGroup": false,\n      "conversationType": "",\n      "tenantId": "",\n      "id": "",\n      "name": "",\n      "aadObjectId": "",\n      "role": ""\n    },\n    "channelId": "",\n    "serviceUrl": "",\n    "locale": ""\n  },\n  "relatesTo": {},\n  "msAppId": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"connectionName\": \"\",\n  \"conversation\": {\n    \"activityId\": \"\",\n    \"user\": {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"bot\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"relatesTo\": {},\n  \"msAppId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/tokenExchangeState")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/tokenExchangeState',
  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({
  connectionName: '',
  conversation: {
    activityId: '',
    user: {id: '', name: '', aadObjectId: '', role: ''},
    bot: {},
    conversation: {
      isGroup: false,
      conversationType: '',
      tenantId: '',
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    channelId: '',
    serviceUrl: '',
    locale: ''
  },
  relatesTo: {},
  msAppId: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/tokenExchangeState',
  headers: {'content-type': 'application/json'},
  body: {
    connectionName: '',
    conversation: {
      activityId: '',
      user: {id: '', name: '', aadObjectId: '', role: ''},
      bot: {},
      conversation: {
        isGroup: false,
        conversationType: '',
        tenantId: '',
        id: '',
        name: '',
        aadObjectId: '',
        role: ''
      },
      channelId: '',
      serviceUrl: '',
      locale: ''
    },
    relatesTo: {},
    msAppId: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/tokenExchangeState');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  connectionName: '',
  conversation: {
    activityId: '',
    user: {
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    bot: {},
    conversation: {
      isGroup: false,
      conversationType: '',
      tenantId: '',
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    channelId: '',
    serviceUrl: '',
    locale: ''
  },
  relatesTo: {},
  msAppId: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/tokenExchangeState',
  headers: {'content-type': 'application/json'},
  data: {
    connectionName: '',
    conversation: {
      activityId: '',
      user: {id: '', name: '', aadObjectId: '', role: ''},
      bot: {},
      conversation: {
        isGroup: false,
        conversationType: '',
        tenantId: '',
        id: '',
        name: '',
        aadObjectId: '',
        role: ''
      },
      channelId: '',
      serviceUrl: '',
      locale: ''
    },
    relatesTo: {},
    msAppId: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/connectorInternals/tokenExchangeState';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"connectionName":"","conversation":{"activityId":"","user":{"id":"","name":"","aadObjectId":"","role":""},"bot":{},"conversation":{"isGroup":false,"conversationType":"","tenantId":"","id":"","name":"","aadObjectId":"","role":""},"channelId":"","serviceUrl":"","locale":""},"relatesTo":{},"msAppId":""}'
};

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 = @{ @"connectionName": @"",
                              @"conversation": @{ @"activityId": @"", @"user": @{ @"id": @"", @"name": @"", @"aadObjectId": @"", @"role": @"" }, @"bot": @{  }, @"conversation": @{ @"isGroup": @NO, @"conversationType": @"", @"tenantId": @"", @"id": @"", @"name": @"", @"aadObjectId": @"", @"role": @"" }, @"channelId": @"", @"serviceUrl": @"", @"locale": @"" },
                              @"relatesTo": @{  },
                              @"msAppId": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/connectorInternals/tokenExchangeState"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/tokenExchangeState" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"connectionName\": \"\",\n  \"conversation\": {\n    \"activityId\": \"\",\n    \"user\": {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"bot\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"relatesTo\": {},\n  \"msAppId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/tokenExchangeState",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'connectionName' => '',
    'conversation' => [
        'activityId' => '',
        'user' => [
                'id' => '',
                'name' => '',
                'aadObjectId' => '',
                'role' => ''
        ],
        'bot' => [
                
        ],
        'conversation' => [
                'isGroup' => null,
                'conversationType' => '',
                'tenantId' => '',
                'id' => '',
                'name' => '',
                'aadObjectId' => '',
                'role' => ''
        ],
        'channelId' => '',
        'serviceUrl' => '',
        'locale' => ''
    ],
    'relatesTo' => [
        
    ],
    'msAppId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/tokenExchangeState', [
  'body' => '{
  "connectionName": "",
  "conversation": {
    "activityId": "",
    "user": {
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "bot": {},
    "conversation": {
      "isGroup": false,
      "conversationType": "",
      "tenantId": "",
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "relatesTo": {},
  "msAppId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/tokenExchangeState');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'connectionName' => '',
  'conversation' => [
    'activityId' => '',
    'user' => [
        'id' => '',
        'name' => '',
        'aadObjectId' => '',
        'role' => ''
    ],
    'bot' => [
        
    ],
    'conversation' => [
        'isGroup' => null,
        'conversationType' => '',
        'tenantId' => '',
        'id' => '',
        'name' => '',
        'aadObjectId' => '',
        'role' => ''
    ],
    'channelId' => '',
    'serviceUrl' => '',
    'locale' => ''
  ],
  'relatesTo' => [
    
  ],
  'msAppId' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'connectionName' => '',
  'conversation' => [
    'activityId' => '',
    'user' => [
        'id' => '',
        'name' => '',
        'aadObjectId' => '',
        'role' => ''
    ],
    'bot' => [
        
    ],
    'conversation' => [
        'isGroup' => null,
        'conversationType' => '',
        'tenantId' => '',
        'id' => '',
        'name' => '',
        'aadObjectId' => '',
        'role' => ''
    ],
    'channelId' => '',
    'serviceUrl' => '',
    'locale' => ''
  ],
  'relatesTo' => [
    
  ],
  'msAppId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/tokenExchangeState');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/tokenExchangeState' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "connectionName": "",
  "conversation": {
    "activityId": "",
    "user": {
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "bot": {},
    "conversation": {
      "isGroup": false,
      "conversationType": "",
      "tenantId": "",
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "relatesTo": {},
  "msAppId": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/tokenExchangeState' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "connectionName": "",
  "conversation": {
    "activityId": "",
    "user": {
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "bot": {},
    "conversation": {
      "isGroup": false,
      "conversationType": "",
      "tenantId": "",
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "relatesTo": {},
  "msAppId": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"connectionName\": \"\",\n  \"conversation\": {\n    \"activityId\": \"\",\n    \"user\": {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"bot\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"relatesTo\": {},\n  \"msAppId\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/connectorInternals/tokenExchangeState", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/connectorInternals/tokenExchangeState"

payload = {
    "connectionName": "",
    "conversation": {
        "activityId": "",
        "user": {
            "id": "",
            "name": "",
            "aadObjectId": "",
            "role": ""
        },
        "bot": {},
        "conversation": {
            "isGroup": False,
            "conversationType": "",
            "tenantId": "",
            "id": "",
            "name": "",
            "aadObjectId": "",
            "role": ""
        },
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
    },
    "relatesTo": {},
    "msAppId": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/connectorInternals/tokenExchangeState"

payload <- "{\n  \"connectionName\": \"\",\n  \"conversation\": {\n    \"activityId\": \"\",\n    \"user\": {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"bot\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"relatesTo\": {},\n  \"msAppId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/connectorInternals/tokenExchangeState")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"connectionName\": \"\",\n  \"conversation\": {\n    \"activityId\": \"\",\n    \"user\": {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"bot\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"relatesTo\": {},\n  \"msAppId\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/connectorInternals/tokenExchangeState') do |req|
  req.body = "{\n  \"connectionName\": \"\",\n  \"conversation\": {\n    \"activityId\": \"\",\n    \"user\": {\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"bot\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"relatesTo\": {},\n  \"msAppId\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/connectorInternals/tokenExchangeState";

    let payload = json!({
        "connectionName": "",
        "conversation": json!({
            "activityId": "",
            "user": json!({
                "id": "",
                "name": "",
                "aadObjectId": "",
                "role": ""
            }),
            "bot": json!({}),
            "conversation": json!({
                "isGroup": false,
                "conversationType": "",
                "tenantId": "",
                "id": "",
                "name": "",
                "aadObjectId": "",
                "role": ""
            }),
            "channelId": "",
            "serviceUrl": "",
            "locale": ""
        }),
        "relatesTo": json!({}),
        "msAppId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/tokenExchangeState \
  --header 'content-type: application/json' \
  --data '{
  "connectionName": "",
  "conversation": {
    "activityId": "",
    "user": {
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "bot": {},
    "conversation": {
      "isGroup": false,
      "conversationType": "",
      "tenantId": "",
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "relatesTo": {},
  "msAppId": ""
}'
echo '{
  "connectionName": "",
  "conversation": {
    "activityId": "",
    "user": {
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "bot": {},
    "conversation": {
      "isGroup": false,
      "conversationType": "",
      "tenantId": "",
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "relatesTo": {},
  "msAppId": ""
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/tokenExchangeState \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "connectionName": "",\n  "conversation": {\n    "activityId": "",\n    "user": {\n      "id": "",\n      "name": "",\n      "aadObjectId": "",\n      "role": ""\n    },\n    "bot": {},\n    "conversation": {\n      "isGroup": false,\n      "conversationType": "",\n      "tenantId": "",\n      "id": "",\n      "name": "",\n      "aadObjectId": "",\n      "role": ""\n    },\n    "channelId": "",\n    "serviceUrl": "",\n    "locale": ""\n  },\n  "relatesTo": {},\n  "msAppId": ""\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/tokenExchangeState
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "connectionName": "",
  "conversation": [
    "activityId": "",
    "user": [
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    ],
    "bot": [],
    "conversation": [
      "isGroup": false,
      "conversationType": "",
      "tenantId": "",
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    ],
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  ],
  "relatesTo": [],
  "msAppId": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/connectorInternals/tokenExchangeState")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST PostTokenResponse
{{baseUrl}}/v3/connectorInternals/tokenResponse
BODY json

{
  "channelId": "",
  "connectionName": "",
  "token": "",
  "expiration": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/tokenResponse");

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  \"channelId\": \"\",\n  \"connectionName\": \"\",\n  \"token\": \"\",\n  \"expiration\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/connectorInternals/tokenResponse" {:content-type :json
                                                                                :form-params {:channelId ""
                                                                                              :connectionName ""
                                                                                              :token ""
                                                                                              :expiration ""}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/tokenResponse"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"channelId\": \"\",\n  \"connectionName\": \"\",\n  \"token\": \"\",\n  \"expiration\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/tokenResponse"),
    Content = new StringContent("{\n  \"channelId\": \"\",\n  \"connectionName\": \"\",\n  \"token\": \"\",\n  \"expiration\": \"\"\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}}/v3/connectorInternals/tokenResponse");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"channelId\": \"\",\n  \"connectionName\": \"\",\n  \"token\": \"\",\n  \"expiration\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/tokenResponse"

	payload := strings.NewReader("{\n  \"channelId\": \"\",\n  \"connectionName\": \"\",\n  \"token\": \"\",\n  \"expiration\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/connectorInternals/tokenResponse HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 80

{
  "channelId": "",
  "connectionName": "",
  "token": "",
  "expiration": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/tokenResponse")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"channelId\": \"\",\n  \"connectionName\": \"\",\n  \"token\": \"\",\n  \"expiration\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/tokenResponse"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"channelId\": \"\",\n  \"connectionName\": \"\",\n  \"token\": \"\",\n  \"expiration\": \"\"\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  \"channelId\": \"\",\n  \"connectionName\": \"\",\n  \"token\": \"\",\n  \"expiration\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/tokenResponse")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/tokenResponse")
  .header("content-type", "application/json")
  .body("{\n  \"channelId\": \"\",\n  \"connectionName\": \"\",\n  \"token\": \"\",\n  \"expiration\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  channelId: '',
  connectionName: '',
  token: '',
  expiration: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/tokenResponse');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/tokenResponse',
  headers: {'content-type': 'application/json'},
  data: {channelId: '', connectionName: '', token: '', expiration: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/tokenResponse';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"channelId":"","connectionName":"","token":"","expiration":""}'
};

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}}/v3/connectorInternals/tokenResponse',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "channelId": "",\n  "connectionName": "",\n  "token": "",\n  "expiration": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"channelId\": \"\",\n  \"connectionName\": \"\",\n  \"token\": \"\",\n  \"expiration\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/tokenResponse")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/tokenResponse',
  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({channelId: '', connectionName: '', token: '', expiration: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/tokenResponse',
  headers: {'content-type': 'application/json'},
  body: {channelId: '', connectionName: '', token: '', expiration: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/tokenResponse');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  channelId: '',
  connectionName: '',
  token: '',
  expiration: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/tokenResponse',
  headers: {'content-type': 'application/json'},
  data: {channelId: '', connectionName: '', token: '', expiration: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/connectorInternals/tokenResponse';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"channelId":"","connectionName":"","token":"","expiration":""}'
};

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 = @{ @"channelId": @"",
                              @"connectionName": @"",
                              @"token": @"",
                              @"expiration": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/connectorInternals/tokenResponse"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/tokenResponse" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"channelId\": \"\",\n  \"connectionName\": \"\",\n  \"token\": \"\",\n  \"expiration\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/tokenResponse",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'channelId' => '',
    'connectionName' => '',
    'token' => '',
    'expiration' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/tokenResponse', [
  'body' => '{
  "channelId": "",
  "connectionName": "",
  "token": "",
  "expiration": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/tokenResponse');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'channelId' => '',
  'connectionName' => '',
  'token' => '',
  'expiration' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'channelId' => '',
  'connectionName' => '',
  'token' => '',
  'expiration' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/tokenResponse');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/tokenResponse' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "channelId": "",
  "connectionName": "",
  "token": "",
  "expiration": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/tokenResponse' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "channelId": "",
  "connectionName": "",
  "token": "",
  "expiration": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"channelId\": \"\",\n  \"connectionName\": \"\",\n  \"token\": \"\",\n  \"expiration\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/connectorInternals/tokenResponse", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/connectorInternals/tokenResponse"

payload = {
    "channelId": "",
    "connectionName": "",
    "token": "",
    "expiration": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/connectorInternals/tokenResponse"

payload <- "{\n  \"channelId\": \"\",\n  \"connectionName\": \"\",\n  \"token\": \"\",\n  \"expiration\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/connectorInternals/tokenResponse")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"channelId\": \"\",\n  \"connectionName\": \"\",\n  \"token\": \"\",\n  \"expiration\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/connectorInternals/tokenResponse') do |req|
  req.body = "{\n  \"channelId\": \"\",\n  \"connectionName\": \"\",\n  \"token\": \"\",\n  \"expiration\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/connectorInternals/tokenResponse";

    let payload = json!({
        "channelId": "",
        "connectionName": "",
        "token": "",
        "expiration": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/tokenResponse \
  --header 'content-type: application/json' \
  --data '{
  "channelId": "",
  "connectionName": "",
  "token": "",
  "expiration": ""
}'
echo '{
  "channelId": "",
  "connectionName": "",
  "token": "",
  "expiration": ""
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/tokenResponse \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "channelId": "",\n  "connectionName": "",\n  "token": "",\n  "expiration": ""\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/tokenResponse
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "channelId": "",
  "connectionName": "",
  "token": "",
  "expiration": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/connectorInternals/tokenResponse")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST PostVideoCard
{{baseUrl}}/v3/connectorInternals/videoCard
BODY json

{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/connectorInternals/videoCard");

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  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/connectorInternals/videoCard" {:content-type :json
                                                                            :form-params {:title ""
                                                                                          :subtitle ""
                                                                                          :text ""
                                                                                          :image {:url ""
                                                                                                  :alt ""}
                                                                                          :media [{:url ""
                                                                                                   :profile ""}]
                                                                                          :buttons [{:type ""
                                                                                                     :title ""
                                                                                                     :image ""
                                                                                                     :imageAltText ""
                                                                                                     :text ""
                                                                                                     :displayText ""
                                                                                                     :value {}
                                                                                                     :channelData {}}]
                                                                                          :shareable false
                                                                                          :autoloop false
                                                                                          :autostart false
                                                                                          :aspect ""
                                                                                          :duration ""
                                                                                          :value {}}})
require "http/client"

url = "{{baseUrl}}/v3/connectorInternals/videoCard"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/connectorInternals/videoCard"),
    Content = new StringContent("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\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}}/v3/connectorInternals/videoCard");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/connectorInternals/videoCard"

	payload := strings.NewReader("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/connectorInternals/videoCard HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 477

{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/connectorInternals/videoCard")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/connectorInternals/videoCard"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\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  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/videoCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/connectorInternals/videoCard")
  .header("content-type", "application/json")
  .body("{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}")
  .asString();
const data = JSON.stringify({
  title: '',
  subtitle: '',
  text: '',
  image: {
    url: '',
    alt: ''
  },
  media: [
    {
      url: '',
      profile: ''
    }
  ],
  buttons: [
    {
      type: '',
      title: '',
      image: '',
      imageAltText: '',
      text: '',
      displayText: '',
      value: {},
      channelData: {}
    }
  ],
  shareable: false,
  autoloop: false,
  autostart: false,
  aspect: '',
  duration: '',
  value: {}
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/connectorInternals/videoCard');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/videoCard',
  headers: {'content-type': 'application/json'},
  data: {
    title: '',
    subtitle: '',
    text: '',
    image: {url: '', alt: ''},
    media: [{url: '', profile: ''}],
    buttons: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ],
    shareable: false,
    autoloop: false,
    autostart: false,
    aspect: '',
    duration: '',
    value: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/connectorInternals/videoCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"title":"","subtitle":"","text":"","image":{"url":"","alt":""},"media":[{"url":"","profile":""}],"buttons":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}],"shareable":false,"autoloop":false,"autostart":false,"aspect":"","duration":"","value":{}}'
};

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}}/v3/connectorInternals/videoCard',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "title": "",\n  "subtitle": "",\n  "text": "",\n  "image": {\n    "url": "",\n    "alt": ""\n  },\n  "media": [\n    {\n      "url": "",\n      "profile": ""\n    }\n  ],\n  "buttons": [\n    {\n      "type": "",\n      "title": "",\n      "image": "",\n      "imageAltText": "",\n      "text": "",\n      "displayText": "",\n      "value": {},\n      "channelData": {}\n    }\n  ],\n  "shareable": false,\n  "autoloop": false,\n  "autostart": false,\n  "aspect": "",\n  "duration": "",\n  "value": {}\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/connectorInternals/videoCard")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/connectorInternals/videoCard',
  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({
  title: '',
  subtitle: '',
  text: '',
  image: {url: '', alt: ''},
  media: [{url: '', profile: ''}],
  buttons: [
    {
      type: '',
      title: '',
      image: '',
      imageAltText: '',
      text: '',
      displayText: '',
      value: {},
      channelData: {}
    }
  ],
  shareable: false,
  autoloop: false,
  autostart: false,
  aspect: '',
  duration: '',
  value: {}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/videoCard',
  headers: {'content-type': 'application/json'},
  body: {
    title: '',
    subtitle: '',
    text: '',
    image: {url: '', alt: ''},
    media: [{url: '', profile: ''}],
    buttons: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ],
    shareable: false,
    autoloop: false,
    autostart: false,
    aspect: '',
    duration: '',
    value: {}
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/connectorInternals/videoCard');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  title: '',
  subtitle: '',
  text: '',
  image: {
    url: '',
    alt: ''
  },
  media: [
    {
      url: '',
      profile: ''
    }
  ],
  buttons: [
    {
      type: '',
      title: '',
      image: '',
      imageAltText: '',
      text: '',
      displayText: '',
      value: {},
      channelData: {}
    }
  ],
  shareable: false,
  autoloop: false,
  autostart: false,
  aspect: '',
  duration: '',
  value: {}
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/connectorInternals/videoCard',
  headers: {'content-type': 'application/json'},
  data: {
    title: '',
    subtitle: '',
    text: '',
    image: {url: '', alt: ''},
    media: [{url: '', profile: ''}],
    buttons: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ],
    shareable: false,
    autoloop: false,
    autostart: false,
    aspect: '',
    duration: '',
    value: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/connectorInternals/videoCard';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"title":"","subtitle":"","text":"","image":{"url":"","alt":""},"media":[{"url":"","profile":""}],"buttons":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}],"shareable":false,"autoloop":false,"autostart":false,"aspect":"","duration":"","value":{}}'
};

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 = @{ @"title": @"",
                              @"subtitle": @"",
                              @"text": @"",
                              @"image": @{ @"url": @"", @"alt": @"" },
                              @"media": @[ @{ @"url": @"", @"profile": @"" } ],
                              @"buttons": @[ @{ @"type": @"", @"title": @"", @"image": @"", @"imageAltText": @"", @"text": @"", @"displayText": @"", @"value": @{  }, @"channelData": @{  } } ],
                              @"shareable": @NO,
                              @"autoloop": @NO,
                              @"autostart": @NO,
                              @"aspect": @"",
                              @"duration": @"",
                              @"value": @{  } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/connectorInternals/videoCard"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/connectorInternals/videoCard" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/connectorInternals/videoCard",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'title' => '',
    'subtitle' => '',
    'text' => '',
    'image' => [
        'url' => '',
        'alt' => ''
    ],
    'media' => [
        [
                'url' => '',
                'profile' => ''
        ]
    ],
    'buttons' => [
        [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ],
    'shareable' => null,
    'autoloop' => null,
    'autostart' => null,
    'aspect' => '',
    'duration' => '',
    'value' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/connectorInternals/videoCard', [
  'body' => '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/connectorInternals/videoCard');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'title' => '',
  'subtitle' => '',
  'text' => '',
  'image' => [
    'url' => '',
    'alt' => ''
  ],
  'media' => [
    [
        'url' => '',
        'profile' => ''
    ]
  ],
  'buttons' => [
    [
        'type' => '',
        'title' => '',
        'image' => '',
        'imageAltText' => '',
        'text' => '',
        'displayText' => '',
        'value' => [
                
        ],
        'channelData' => [
                
        ]
    ]
  ],
  'shareable' => null,
  'autoloop' => null,
  'autostart' => null,
  'aspect' => '',
  'duration' => '',
  'value' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'title' => '',
  'subtitle' => '',
  'text' => '',
  'image' => [
    'url' => '',
    'alt' => ''
  ],
  'media' => [
    [
        'url' => '',
        'profile' => ''
    ]
  ],
  'buttons' => [
    [
        'type' => '',
        'title' => '',
        'image' => '',
        'imageAltText' => '',
        'text' => '',
        'displayText' => '',
        'value' => [
                
        ],
        'channelData' => [
                
        ]
    ]
  ],
  'shareable' => null,
  'autoloop' => null,
  'autostart' => null,
  'aspect' => '',
  'duration' => '',
  'value' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/connectorInternals/videoCard');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/connectorInternals/videoCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/connectorInternals/videoCard' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/connectorInternals/videoCard", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/connectorInternals/videoCard"

payload = {
    "title": "",
    "subtitle": "",
    "text": "",
    "image": {
        "url": "",
        "alt": ""
    },
    "media": [
        {
            "url": "",
            "profile": ""
        }
    ],
    "buttons": [
        {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
        }
    ],
    "shareable": False,
    "autoloop": False,
    "autostart": False,
    "aspect": "",
    "duration": "",
    "value": {}
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/connectorInternals/videoCard"

payload <- "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/connectorInternals/videoCard")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/connectorInternals/videoCard') do |req|
  req.body = "{\n  \"title\": \"\",\n  \"subtitle\": \"\",\n  \"text\": \"\",\n  \"image\": {\n    \"url\": \"\",\n    \"alt\": \"\"\n  },\n  \"media\": [\n    {\n      \"url\": \"\",\n      \"profile\": \"\"\n    }\n  ],\n  \"buttons\": [\n    {\n      \"type\": \"\",\n      \"title\": \"\",\n      \"image\": \"\",\n      \"imageAltText\": \"\",\n      \"text\": \"\",\n      \"displayText\": \"\",\n      \"value\": {},\n      \"channelData\": {}\n    }\n  ],\n  \"shareable\": false,\n  \"autoloop\": false,\n  \"autostart\": false,\n  \"aspect\": \"\",\n  \"duration\": \"\",\n  \"value\": {}\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/connectorInternals/videoCard";

    let payload = json!({
        "title": "",
        "subtitle": "",
        "text": "",
        "image": json!({
            "url": "",
            "alt": ""
        }),
        "media": (
            json!({
                "url": "",
                "profile": ""
            })
        ),
        "buttons": (
            json!({
                "type": "",
                "title": "",
                "image": "",
                "imageAltText": "",
                "text": "",
                "displayText": "",
                "value": json!({}),
                "channelData": json!({})
            })
        ),
        "shareable": false,
        "autoloop": false,
        "autostart": false,
        "aspect": "",
        "duration": "",
        "value": json!({})
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/connectorInternals/videoCard \
  --header 'content-type: application/json' \
  --data '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}'
echo '{
  "title": "",
  "subtitle": "",
  "text": "",
  "image": {
    "url": "",
    "alt": ""
  },
  "media": [
    {
      "url": "",
      "profile": ""
    }
  ],
  "buttons": [
    {
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": {},
      "channelData": {}
    }
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": {}
}' |  \
  http POST {{baseUrl}}/v3/connectorInternals/videoCard \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "title": "",\n  "subtitle": "",\n  "text": "",\n  "image": {\n    "url": "",\n    "alt": ""\n  },\n  "media": [\n    {\n      "url": "",\n      "profile": ""\n    }\n  ],\n  "buttons": [\n    {\n      "type": "",\n      "title": "",\n      "image": "",\n      "imageAltText": "",\n      "text": "",\n      "displayText": "",\n      "value": {},\n      "channelData": {}\n    }\n  ],\n  "shareable": false,\n  "autoloop": false,\n  "autostart": false,\n  "aspect": "",\n  "duration": "",\n  "value": {}\n}' \
  --output-document \
  - {{baseUrl}}/v3/connectorInternals/videoCard
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "title": "",
  "subtitle": "",
  "text": "",
  "image": [
    "url": "",
    "alt": ""
  ],
  "media": [
    [
      "url": "",
      "profile": ""
    ]
  ],
  "buttons": [
    [
      "type": "",
      "title": "",
      "image": "",
      "imageAltText": "",
      "text": "",
      "displayText": "",
      "value": [],
      "channelData": []
    ]
  ],
  "shareable": false,
  "autoloop": false,
  "autostart": false,
  "aspect": "",
  "duration": "",
  "value": []
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/connectorInternals/videoCard")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CreateConversation
{{baseUrl}}/v3/conversations
BODY json

{
  "isGroup": false,
  "bot": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "members": [
    {}
  ],
  "topicName": "",
  "tenantId": "",
  "activity": {
    "type": "",
    "id": "",
    "timestamp": "",
    "localTimestamp": "",
    "localTimezone": "",
    "callerId": "",
    "serviceUrl": "",
    "channelId": "",
    "from": {},
    "conversation": {
      "isGroup": false,
      "conversationType": "",
      "tenantId": "",
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "recipient": {},
    "textFormat": "",
    "attachmentLayout": "",
    "membersAdded": [
      {}
    ],
    "membersRemoved": [
      {}
    ],
    "reactionsAdded": [
      {
        "type": ""
      }
    ],
    "reactionsRemoved": [
      {}
    ],
    "topicName": "",
    "historyDisclosed": false,
    "locale": "",
    "text": "",
    "speak": "",
    "inputHint": "",
    "summary": "",
    "suggestedActions": {
      "to": [],
      "actions": [
        {
          "type": "",
          "title": "",
          "image": "",
          "imageAltText": "",
          "text": "",
          "displayText": "",
          "value": {},
          "channelData": {}
        }
      ]
    },
    "attachments": [
      {
        "contentType": "",
        "contentUrl": "",
        "content": {},
        "name": "",
        "thumbnailUrl": ""
      }
    ],
    "entities": [
      {
        "type": ""
      }
    ],
    "channelData": {},
    "action": "",
    "replyToId": "",
    "label": "",
    "valueType": "",
    "value": {},
    "name": "",
    "relatesTo": {
      "activityId": "",
      "user": {},
      "bot": {},
      "conversation": {},
      "channelId": "",
      "serviceUrl": "",
      "locale": ""
    },
    "code": "",
    "expiration": "",
    "importance": "",
    "deliveryMode": "",
    "listenFor": [],
    "textHighlights": [
      {
        "text": "",
        "occurrence": 0
      }
    ],
    "semanticAction": {
      "state": "",
      "id": "",
      "entities": {}
    }
  },
  "channelData": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/conversations");

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  \"isGroup\": false,\n  \"bot\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"members\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"tenantId\": \"\",\n  \"activity\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"timestamp\": \"\",\n    \"localTimestamp\": \"\",\n    \"localTimezone\": \"\",\n    \"callerId\": \"\",\n    \"serviceUrl\": \"\",\n    \"channelId\": \"\",\n    \"from\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"recipient\": {},\n    \"textFormat\": \"\",\n    \"attachmentLayout\": \"\",\n    \"membersAdded\": [\n      {}\n    ],\n    \"membersRemoved\": [\n      {}\n    ],\n    \"reactionsAdded\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"reactionsRemoved\": [\n      {}\n    ],\n    \"topicName\": \"\",\n    \"historyDisclosed\": false,\n    \"locale\": \"\",\n    \"text\": \"\",\n    \"speak\": \"\",\n    \"inputHint\": \"\",\n    \"summary\": \"\",\n    \"suggestedActions\": {\n      \"to\": [],\n      \"actions\": [\n        {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      ]\n    },\n    \"attachments\": [\n      {\n        \"contentType\": \"\",\n        \"contentUrl\": \"\",\n        \"content\": {},\n        \"name\": \"\",\n        \"thumbnailUrl\": \"\"\n      }\n    ],\n    \"entities\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"channelData\": {},\n    \"action\": \"\",\n    \"replyToId\": \"\",\n    \"label\": \"\",\n    \"valueType\": \"\",\n    \"value\": {},\n    \"name\": \"\",\n    \"relatesTo\": {\n      \"activityId\": \"\",\n      \"user\": {},\n      \"bot\": {},\n      \"conversation\": {},\n      \"channelId\": \"\",\n      \"serviceUrl\": \"\",\n      \"locale\": \"\"\n    },\n    \"code\": \"\",\n    \"expiration\": \"\",\n    \"importance\": \"\",\n    \"deliveryMode\": \"\",\n    \"listenFor\": [],\n    \"textHighlights\": [\n      {\n        \"text\": \"\",\n        \"occurrence\": 0\n      }\n    ],\n    \"semanticAction\": {\n      \"state\": \"\",\n      \"id\": \"\",\n      \"entities\": {}\n    }\n  },\n  \"channelData\": {}\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/conversations" {:content-type :json
                                                             :form-params {:isGroup false
                                                                           :bot {:id ""
                                                                                 :name ""
                                                                                 :aadObjectId ""
                                                                                 :role ""}
                                                                           :members [{}]
                                                                           :topicName ""
                                                                           :tenantId ""
                                                                           :activity {:type ""
                                                                                      :id ""
                                                                                      :timestamp ""
                                                                                      :localTimestamp ""
                                                                                      :localTimezone ""
                                                                                      :callerId ""
                                                                                      :serviceUrl ""
                                                                                      :channelId ""
                                                                                      :from {}
                                                                                      :conversation {:isGroup false
                                                                                                     :conversationType ""
                                                                                                     :tenantId ""
                                                                                                     :id ""
                                                                                                     :name ""
                                                                                                     :aadObjectId ""
                                                                                                     :role ""}
                                                                                      :recipient {}
                                                                                      :textFormat ""
                                                                                      :attachmentLayout ""
                                                                                      :membersAdded [{}]
                                                                                      :membersRemoved [{}]
                                                                                      :reactionsAdded [{:type ""}]
                                                                                      :reactionsRemoved [{}]
                                                                                      :topicName ""
                                                                                      :historyDisclosed false
                                                                                      :locale ""
                                                                                      :text ""
                                                                                      :speak ""
                                                                                      :inputHint ""
                                                                                      :summary ""
                                                                                      :suggestedActions {:to []
                                                                                                         :actions [{:type ""
                                                                                                                    :title ""
                                                                                                                    :image ""
                                                                                                                    :imageAltText ""
                                                                                                                    :text ""
                                                                                                                    :displayText ""
                                                                                                                    :value {}
                                                                                                                    :channelData {}}]}
                                                                                      :attachments [{:contentType ""
                                                                                                     :contentUrl ""
                                                                                                     :content {}
                                                                                                     :name ""
                                                                                                     :thumbnailUrl ""}]
                                                                                      :entities [{:type ""}]
                                                                                      :channelData {}
                                                                                      :action ""
                                                                                      :replyToId ""
                                                                                      :label ""
                                                                                      :valueType ""
                                                                                      :value {}
                                                                                      :name ""
                                                                                      :relatesTo {:activityId ""
                                                                                                  :user {}
                                                                                                  :bot {}
                                                                                                  :conversation {}
                                                                                                  :channelId ""
                                                                                                  :serviceUrl ""
                                                                                                  :locale ""}
                                                                                      :code ""
                                                                                      :expiration ""
                                                                                      :importance ""
                                                                                      :deliveryMode ""
                                                                                      :listenFor []
                                                                                      :textHighlights [{:text ""
                                                                                                        :occurrence 0}]
                                                                                      :semanticAction {:state ""
                                                                                                       :id ""
                                                                                                       :entities {}}}
                                                                           :channelData {}}})
require "http/client"

url = "{{baseUrl}}/v3/conversations"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"isGroup\": false,\n  \"bot\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"members\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"tenantId\": \"\",\n  \"activity\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"timestamp\": \"\",\n    \"localTimestamp\": \"\",\n    \"localTimezone\": \"\",\n    \"callerId\": \"\",\n    \"serviceUrl\": \"\",\n    \"channelId\": \"\",\n    \"from\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"recipient\": {},\n    \"textFormat\": \"\",\n    \"attachmentLayout\": \"\",\n    \"membersAdded\": [\n      {}\n    ],\n    \"membersRemoved\": [\n      {}\n    ],\n    \"reactionsAdded\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"reactionsRemoved\": [\n      {}\n    ],\n    \"topicName\": \"\",\n    \"historyDisclosed\": false,\n    \"locale\": \"\",\n    \"text\": \"\",\n    \"speak\": \"\",\n    \"inputHint\": \"\",\n    \"summary\": \"\",\n    \"suggestedActions\": {\n      \"to\": [],\n      \"actions\": [\n        {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      ]\n    },\n    \"attachments\": [\n      {\n        \"contentType\": \"\",\n        \"contentUrl\": \"\",\n        \"content\": {},\n        \"name\": \"\",\n        \"thumbnailUrl\": \"\"\n      }\n    ],\n    \"entities\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"channelData\": {},\n    \"action\": \"\",\n    \"replyToId\": \"\",\n    \"label\": \"\",\n    \"valueType\": \"\",\n    \"value\": {},\n    \"name\": \"\",\n    \"relatesTo\": {\n      \"activityId\": \"\",\n      \"user\": {},\n      \"bot\": {},\n      \"conversation\": {},\n      \"channelId\": \"\",\n      \"serviceUrl\": \"\",\n      \"locale\": \"\"\n    },\n    \"code\": \"\",\n    \"expiration\": \"\",\n    \"importance\": \"\",\n    \"deliveryMode\": \"\",\n    \"listenFor\": [],\n    \"textHighlights\": [\n      {\n        \"text\": \"\",\n        \"occurrence\": 0\n      }\n    ],\n    \"semanticAction\": {\n      \"state\": \"\",\n      \"id\": \"\",\n      \"entities\": {}\n    }\n  },\n  \"channelData\": {}\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/conversations"),
    Content = new StringContent("{\n  \"isGroup\": false,\n  \"bot\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"members\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"tenantId\": \"\",\n  \"activity\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"timestamp\": \"\",\n    \"localTimestamp\": \"\",\n    \"localTimezone\": \"\",\n    \"callerId\": \"\",\n    \"serviceUrl\": \"\",\n    \"channelId\": \"\",\n    \"from\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"recipient\": {},\n    \"textFormat\": \"\",\n    \"attachmentLayout\": \"\",\n    \"membersAdded\": [\n      {}\n    ],\n    \"membersRemoved\": [\n      {}\n    ],\n    \"reactionsAdded\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"reactionsRemoved\": [\n      {}\n    ],\n    \"topicName\": \"\",\n    \"historyDisclosed\": false,\n    \"locale\": \"\",\n    \"text\": \"\",\n    \"speak\": \"\",\n    \"inputHint\": \"\",\n    \"summary\": \"\",\n    \"suggestedActions\": {\n      \"to\": [],\n      \"actions\": [\n        {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      ]\n    },\n    \"attachments\": [\n      {\n        \"contentType\": \"\",\n        \"contentUrl\": \"\",\n        \"content\": {},\n        \"name\": \"\",\n        \"thumbnailUrl\": \"\"\n      }\n    ],\n    \"entities\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"channelData\": {},\n    \"action\": \"\",\n    \"replyToId\": \"\",\n    \"label\": \"\",\n    \"valueType\": \"\",\n    \"value\": {},\n    \"name\": \"\",\n    \"relatesTo\": {\n      \"activityId\": \"\",\n      \"user\": {},\n      \"bot\": {},\n      \"conversation\": {},\n      \"channelId\": \"\",\n      \"serviceUrl\": \"\",\n      \"locale\": \"\"\n    },\n    \"code\": \"\",\n    \"expiration\": \"\",\n    \"importance\": \"\",\n    \"deliveryMode\": \"\",\n    \"listenFor\": [],\n    \"textHighlights\": [\n      {\n        \"text\": \"\",\n        \"occurrence\": 0\n      }\n    ],\n    \"semanticAction\": {\n      \"state\": \"\",\n      \"id\": \"\",\n      \"entities\": {}\n    }\n  },\n  \"channelData\": {}\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}}/v3/conversations");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"isGroup\": false,\n  \"bot\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"members\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"tenantId\": \"\",\n  \"activity\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"timestamp\": \"\",\n    \"localTimestamp\": \"\",\n    \"localTimezone\": \"\",\n    \"callerId\": \"\",\n    \"serviceUrl\": \"\",\n    \"channelId\": \"\",\n    \"from\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"recipient\": {},\n    \"textFormat\": \"\",\n    \"attachmentLayout\": \"\",\n    \"membersAdded\": [\n      {}\n    ],\n    \"membersRemoved\": [\n      {}\n    ],\n    \"reactionsAdded\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"reactionsRemoved\": [\n      {}\n    ],\n    \"topicName\": \"\",\n    \"historyDisclosed\": false,\n    \"locale\": \"\",\n    \"text\": \"\",\n    \"speak\": \"\",\n    \"inputHint\": \"\",\n    \"summary\": \"\",\n    \"suggestedActions\": {\n      \"to\": [],\n      \"actions\": [\n        {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      ]\n    },\n    \"attachments\": [\n      {\n        \"contentType\": \"\",\n        \"contentUrl\": \"\",\n        \"content\": {},\n        \"name\": \"\",\n        \"thumbnailUrl\": \"\"\n      }\n    ],\n    \"entities\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"channelData\": {},\n    \"action\": \"\",\n    \"replyToId\": \"\",\n    \"label\": \"\",\n    \"valueType\": \"\",\n    \"value\": {},\n    \"name\": \"\",\n    \"relatesTo\": {\n      \"activityId\": \"\",\n      \"user\": {},\n      \"bot\": {},\n      \"conversation\": {},\n      \"channelId\": \"\",\n      \"serviceUrl\": \"\",\n      \"locale\": \"\"\n    },\n    \"code\": \"\",\n    \"expiration\": \"\",\n    \"importance\": \"\",\n    \"deliveryMode\": \"\",\n    \"listenFor\": [],\n    \"textHighlights\": [\n      {\n        \"text\": \"\",\n        \"occurrence\": 0\n      }\n    ],\n    \"semanticAction\": {\n      \"state\": \"\",\n      \"id\": \"\",\n      \"entities\": {}\n    }\n  },\n  \"channelData\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/conversations"

	payload := strings.NewReader("{\n  \"isGroup\": false,\n  \"bot\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"members\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"tenantId\": \"\",\n  \"activity\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"timestamp\": \"\",\n    \"localTimestamp\": \"\",\n    \"localTimezone\": \"\",\n    \"callerId\": \"\",\n    \"serviceUrl\": \"\",\n    \"channelId\": \"\",\n    \"from\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"recipient\": {},\n    \"textFormat\": \"\",\n    \"attachmentLayout\": \"\",\n    \"membersAdded\": [\n      {}\n    ],\n    \"membersRemoved\": [\n      {}\n    ],\n    \"reactionsAdded\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"reactionsRemoved\": [\n      {}\n    ],\n    \"topicName\": \"\",\n    \"historyDisclosed\": false,\n    \"locale\": \"\",\n    \"text\": \"\",\n    \"speak\": \"\",\n    \"inputHint\": \"\",\n    \"summary\": \"\",\n    \"suggestedActions\": {\n      \"to\": [],\n      \"actions\": [\n        {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      ]\n    },\n    \"attachments\": [\n      {\n        \"contentType\": \"\",\n        \"contentUrl\": \"\",\n        \"content\": {},\n        \"name\": \"\",\n        \"thumbnailUrl\": \"\"\n      }\n    ],\n    \"entities\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"channelData\": {},\n    \"action\": \"\",\n    \"replyToId\": \"\",\n    \"label\": \"\",\n    \"valueType\": \"\",\n    \"value\": {},\n    \"name\": \"\",\n    \"relatesTo\": {\n      \"activityId\": \"\",\n      \"user\": {},\n      \"bot\": {},\n      \"conversation\": {},\n      \"channelId\": \"\",\n      \"serviceUrl\": \"\",\n      \"locale\": \"\"\n    },\n    \"code\": \"\",\n    \"expiration\": \"\",\n    \"importance\": \"\",\n    \"deliveryMode\": \"\",\n    \"listenFor\": [],\n    \"textHighlights\": [\n      {\n        \"text\": \"\",\n        \"occurrence\": 0\n      }\n    ],\n    \"semanticAction\": {\n      \"state\": \"\",\n      \"id\": \"\",\n      \"entities\": {}\n    }\n  },\n  \"channelData\": {}\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/conversations HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2089

{
  "isGroup": false,
  "bot": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "members": [
    {}
  ],
  "topicName": "",
  "tenantId": "",
  "activity": {
    "type": "",
    "id": "",
    "timestamp": "",
    "localTimestamp": "",
    "localTimezone": "",
    "callerId": "",
    "serviceUrl": "",
    "channelId": "",
    "from": {},
    "conversation": {
      "isGroup": false,
      "conversationType": "",
      "tenantId": "",
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "recipient": {},
    "textFormat": "",
    "attachmentLayout": "",
    "membersAdded": [
      {}
    ],
    "membersRemoved": [
      {}
    ],
    "reactionsAdded": [
      {
        "type": ""
      }
    ],
    "reactionsRemoved": [
      {}
    ],
    "topicName": "",
    "historyDisclosed": false,
    "locale": "",
    "text": "",
    "speak": "",
    "inputHint": "",
    "summary": "",
    "suggestedActions": {
      "to": [],
      "actions": [
        {
          "type": "",
          "title": "",
          "image": "",
          "imageAltText": "",
          "text": "",
          "displayText": "",
          "value": {},
          "channelData": {}
        }
      ]
    },
    "attachments": [
      {
        "contentType": "",
        "contentUrl": "",
        "content": {},
        "name": "",
        "thumbnailUrl": ""
      }
    ],
    "entities": [
      {
        "type": ""
      }
    ],
    "channelData": {},
    "action": "",
    "replyToId": "",
    "label": "",
    "valueType": "",
    "value": {},
    "name": "",
    "relatesTo": {
      "activityId": "",
      "user": {},
      "bot": {},
      "conversation": {},
      "channelId": "",
      "serviceUrl": "",
      "locale": ""
    },
    "code": "",
    "expiration": "",
    "importance": "",
    "deliveryMode": "",
    "listenFor": [],
    "textHighlights": [
      {
        "text": "",
        "occurrence": 0
      }
    ],
    "semanticAction": {
      "state": "",
      "id": "",
      "entities": {}
    }
  },
  "channelData": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/conversations")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"isGroup\": false,\n  \"bot\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"members\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"tenantId\": \"\",\n  \"activity\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"timestamp\": \"\",\n    \"localTimestamp\": \"\",\n    \"localTimezone\": \"\",\n    \"callerId\": \"\",\n    \"serviceUrl\": \"\",\n    \"channelId\": \"\",\n    \"from\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"recipient\": {},\n    \"textFormat\": \"\",\n    \"attachmentLayout\": \"\",\n    \"membersAdded\": [\n      {}\n    ],\n    \"membersRemoved\": [\n      {}\n    ],\n    \"reactionsAdded\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"reactionsRemoved\": [\n      {}\n    ],\n    \"topicName\": \"\",\n    \"historyDisclosed\": false,\n    \"locale\": \"\",\n    \"text\": \"\",\n    \"speak\": \"\",\n    \"inputHint\": \"\",\n    \"summary\": \"\",\n    \"suggestedActions\": {\n      \"to\": [],\n      \"actions\": [\n        {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      ]\n    },\n    \"attachments\": [\n      {\n        \"contentType\": \"\",\n        \"contentUrl\": \"\",\n        \"content\": {},\n        \"name\": \"\",\n        \"thumbnailUrl\": \"\"\n      }\n    ],\n    \"entities\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"channelData\": {},\n    \"action\": \"\",\n    \"replyToId\": \"\",\n    \"label\": \"\",\n    \"valueType\": \"\",\n    \"value\": {},\n    \"name\": \"\",\n    \"relatesTo\": {\n      \"activityId\": \"\",\n      \"user\": {},\n      \"bot\": {},\n      \"conversation\": {},\n      \"channelId\": \"\",\n      \"serviceUrl\": \"\",\n      \"locale\": \"\"\n    },\n    \"code\": \"\",\n    \"expiration\": \"\",\n    \"importance\": \"\",\n    \"deliveryMode\": \"\",\n    \"listenFor\": [],\n    \"textHighlights\": [\n      {\n        \"text\": \"\",\n        \"occurrence\": 0\n      }\n    ],\n    \"semanticAction\": {\n      \"state\": \"\",\n      \"id\": \"\",\n      \"entities\": {}\n    }\n  },\n  \"channelData\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/conversations"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"isGroup\": false,\n  \"bot\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"members\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"tenantId\": \"\",\n  \"activity\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"timestamp\": \"\",\n    \"localTimestamp\": \"\",\n    \"localTimezone\": \"\",\n    \"callerId\": \"\",\n    \"serviceUrl\": \"\",\n    \"channelId\": \"\",\n    \"from\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"recipient\": {},\n    \"textFormat\": \"\",\n    \"attachmentLayout\": \"\",\n    \"membersAdded\": [\n      {}\n    ],\n    \"membersRemoved\": [\n      {}\n    ],\n    \"reactionsAdded\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"reactionsRemoved\": [\n      {}\n    ],\n    \"topicName\": \"\",\n    \"historyDisclosed\": false,\n    \"locale\": \"\",\n    \"text\": \"\",\n    \"speak\": \"\",\n    \"inputHint\": \"\",\n    \"summary\": \"\",\n    \"suggestedActions\": {\n      \"to\": [],\n      \"actions\": [\n        {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      ]\n    },\n    \"attachments\": [\n      {\n        \"contentType\": \"\",\n        \"contentUrl\": \"\",\n        \"content\": {},\n        \"name\": \"\",\n        \"thumbnailUrl\": \"\"\n      }\n    ],\n    \"entities\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"channelData\": {},\n    \"action\": \"\",\n    \"replyToId\": \"\",\n    \"label\": \"\",\n    \"valueType\": \"\",\n    \"value\": {},\n    \"name\": \"\",\n    \"relatesTo\": {\n      \"activityId\": \"\",\n      \"user\": {},\n      \"bot\": {},\n      \"conversation\": {},\n      \"channelId\": \"\",\n      \"serviceUrl\": \"\",\n      \"locale\": \"\"\n    },\n    \"code\": \"\",\n    \"expiration\": \"\",\n    \"importance\": \"\",\n    \"deliveryMode\": \"\",\n    \"listenFor\": [],\n    \"textHighlights\": [\n      {\n        \"text\": \"\",\n        \"occurrence\": 0\n      }\n    ],\n    \"semanticAction\": {\n      \"state\": \"\",\n      \"id\": \"\",\n      \"entities\": {}\n    }\n  },\n  \"channelData\": {}\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  \"isGroup\": false,\n  \"bot\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"members\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"tenantId\": \"\",\n  \"activity\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"timestamp\": \"\",\n    \"localTimestamp\": \"\",\n    \"localTimezone\": \"\",\n    \"callerId\": \"\",\n    \"serviceUrl\": \"\",\n    \"channelId\": \"\",\n    \"from\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"recipient\": {},\n    \"textFormat\": \"\",\n    \"attachmentLayout\": \"\",\n    \"membersAdded\": [\n      {}\n    ],\n    \"membersRemoved\": [\n      {}\n    ],\n    \"reactionsAdded\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"reactionsRemoved\": [\n      {}\n    ],\n    \"topicName\": \"\",\n    \"historyDisclosed\": false,\n    \"locale\": \"\",\n    \"text\": \"\",\n    \"speak\": \"\",\n    \"inputHint\": \"\",\n    \"summary\": \"\",\n    \"suggestedActions\": {\n      \"to\": [],\n      \"actions\": [\n        {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      ]\n    },\n    \"attachments\": [\n      {\n        \"contentType\": \"\",\n        \"contentUrl\": \"\",\n        \"content\": {},\n        \"name\": \"\",\n        \"thumbnailUrl\": \"\"\n      }\n    ],\n    \"entities\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"channelData\": {},\n    \"action\": \"\",\n    \"replyToId\": \"\",\n    \"label\": \"\",\n    \"valueType\": \"\",\n    \"value\": {},\n    \"name\": \"\",\n    \"relatesTo\": {\n      \"activityId\": \"\",\n      \"user\": {},\n      \"bot\": {},\n      \"conversation\": {},\n      \"channelId\": \"\",\n      \"serviceUrl\": \"\",\n      \"locale\": \"\"\n    },\n    \"code\": \"\",\n    \"expiration\": \"\",\n    \"importance\": \"\",\n    \"deliveryMode\": \"\",\n    \"listenFor\": [],\n    \"textHighlights\": [\n      {\n        \"text\": \"\",\n        \"occurrence\": 0\n      }\n    ],\n    \"semanticAction\": {\n      \"state\": \"\",\n      \"id\": \"\",\n      \"entities\": {}\n    }\n  },\n  \"channelData\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/conversations")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/conversations")
  .header("content-type", "application/json")
  .body("{\n  \"isGroup\": false,\n  \"bot\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"members\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"tenantId\": \"\",\n  \"activity\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"timestamp\": \"\",\n    \"localTimestamp\": \"\",\n    \"localTimezone\": \"\",\n    \"callerId\": \"\",\n    \"serviceUrl\": \"\",\n    \"channelId\": \"\",\n    \"from\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"recipient\": {},\n    \"textFormat\": \"\",\n    \"attachmentLayout\": \"\",\n    \"membersAdded\": [\n      {}\n    ],\n    \"membersRemoved\": [\n      {}\n    ],\n    \"reactionsAdded\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"reactionsRemoved\": [\n      {}\n    ],\n    \"topicName\": \"\",\n    \"historyDisclosed\": false,\n    \"locale\": \"\",\n    \"text\": \"\",\n    \"speak\": \"\",\n    \"inputHint\": \"\",\n    \"summary\": \"\",\n    \"suggestedActions\": {\n      \"to\": [],\n      \"actions\": [\n        {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      ]\n    },\n    \"attachments\": [\n      {\n        \"contentType\": \"\",\n        \"contentUrl\": \"\",\n        \"content\": {},\n        \"name\": \"\",\n        \"thumbnailUrl\": \"\"\n      }\n    ],\n    \"entities\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"channelData\": {},\n    \"action\": \"\",\n    \"replyToId\": \"\",\n    \"label\": \"\",\n    \"valueType\": \"\",\n    \"value\": {},\n    \"name\": \"\",\n    \"relatesTo\": {\n      \"activityId\": \"\",\n      \"user\": {},\n      \"bot\": {},\n      \"conversation\": {},\n      \"channelId\": \"\",\n      \"serviceUrl\": \"\",\n      \"locale\": \"\"\n    },\n    \"code\": \"\",\n    \"expiration\": \"\",\n    \"importance\": \"\",\n    \"deliveryMode\": \"\",\n    \"listenFor\": [],\n    \"textHighlights\": [\n      {\n        \"text\": \"\",\n        \"occurrence\": 0\n      }\n    ],\n    \"semanticAction\": {\n      \"state\": \"\",\n      \"id\": \"\",\n      \"entities\": {}\n    }\n  },\n  \"channelData\": {}\n}")
  .asString();
const data = JSON.stringify({
  isGroup: false,
  bot: {
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  members: [
    {}
  ],
  topicName: '',
  tenantId: '',
  activity: {
    type: '',
    id: '',
    timestamp: '',
    localTimestamp: '',
    localTimezone: '',
    callerId: '',
    serviceUrl: '',
    channelId: '',
    from: {},
    conversation: {
      isGroup: false,
      conversationType: '',
      tenantId: '',
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    recipient: {},
    textFormat: '',
    attachmentLayout: '',
    membersAdded: [
      {}
    ],
    membersRemoved: [
      {}
    ],
    reactionsAdded: [
      {
        type: ''
      }
    ],
    reactionsRemoved: [
      {}
    ],
    topicName: '',
    historyDisclosed: false,
    locale: '',
    text: '',
    speak: '',
    inputHint: '',
    summary: '',
    suggestedActions: {
      to: [],
      actions: [
        {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      ]
    },
    attachments: [
      {
        contentType: '',
        contentUrl: '',
        content: {},
        name: '',
        thumbnailUrl: ''
      }
    ],
    entities: [
      {
        type: ''
      }
    ],
    channelData: {},
    action: '',
    replyToId: '',
    label: '',
    valueType: '',
    value: {},
    name: '',
    relatesTo: {
      activityId: '',
      user: {},
      bot: {},
      conversation: {},
      channelId: '',
      serviceUrl: '',
      locale: ''
    },
    code: '',
    expiration: '',
    importance: '',
    deliveryMode: '',
    listenFor: [],
    textHighlights: [
      {
        text: '',
        occurrence: 0
      }
    ],
    semanticAction: {
      state: '',
      id: '',
      entities: {}
    }
  },
  channelData: {}
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/conversations');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/conversations',
  headers: {'content-type': 'application/json'},
  data: {
    isGroup: false,
    bot: {id: '', name: '', aadObjectId: '', role: ''},
    members: [{}],
    topicName: '',
    tenantId: '',
    activity: {
      type: '',
      id: '',
      timestamp: '',
      localTimestamp: '',
      localTimezone: '',
      callerId: '',
      serviceUrl: '',
      channelId: '',
      from: {},
      conversation: {
        isGroup: false,
        conversationType: '',
        tenantId: '',
        id: '',
        name: '',
        aadObjectId: '',
        role: ''
      },
      recipient: {},
      textFormat: '',
      attachmentLayout: '',
      membersAdded: [{}],
      membersRemoved: [{}],
      reactionsAdded: [{type: ''}],
      reactionsRemoved: [{}],
      topicName: '',
      historyDisclosed: false,
      locale: '',
      text: '',
      speak: '',
      inputHint: '',
      summary: '',
      suggestedActions: {
        to: [],
        actions: [
          {
            type: '',
            title: '',
            image: '',
            imageAltText: '',
            text: '',
            displayText: '',
            value: {},
            channelData: {}
          }
        ]
      },
      attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
      entities: [{type: ''}],
      channelData: {},
      action: '',
      replyToId: '',
      label: '',
      valueType: '',
      value: {},
      name: '',
      relatesTo: {
        activityId: '',
        user: {},
        bot: {},
        conversation: {},
        channelId: '',
        serviceUrl: '',
        locale: ''
      },
      code: '',
      expiration: '',
      importance: '',
      deliveryMode: '',
      listenFor: [],
      textHighlights: [{text: '', occurrence: 0}],
      semanticAction: {state: '', id: '', entities: {}}
    },
    channelData: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/conversations';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"isGroup":false,"bot":{"id":"","name":"","aadObjectId":"","role":""},"members":[{}],"topicName":"","tenantId":"","activity":{"type":"","id":"","timestamp":"","localTimestamp":"","localTimezone":"","callerId":"","serviceUrl":"","channelId":"","from":{},"conversation":{"isGroup":false,"conversationType":"","tenantId":"","id":"","name":"","aadObjectId":"","role":""},"recipient":{},"textFormat":"","attachmentLayout":"","membersAdded":[{}],"membersRemoved":[{}],"reactionsAdded":[{"type":""}],"reactionsRemoved":[{}],"topicName":"","historyDisclosed":false,"locale":"","text":"","speak":"","inputHint":"","summary":"","suggestedActions":{"to":[],"actions":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}]},"attachments":[{"contentType":"","contentUrl":"","content":{},"name":"","thumbnailUrl":""}],"entities":[{"type":""}],"channelData":{},"action":"","replyToId":"","label":"","valueType":"","value":{},"name":"","relatesTo":{"activityId":"","user":{},"bot":{},"conversation":{},"channelId":"","serviceUrl":"","locale":""},"code":"","expiration":"","importance":"","deliveryMode":"","listenFor":[],"textHighlights":[{"text":"","occurrence":0}],"semanticAction":{"state":"","id":"","entities":{}}},"channelData":{}}'
};

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}}/v3/conversations',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "isGroup": false,\n  "bot": {\n    "id": "",\n    "name": "",\n    "aadObjectId": "",\n    "role": ""\n  },\n  "members": [\n    {}\n  ],\n  "topicName": "",\n  "tenantId": "",\n  "activity": {\n    "type": "",\n    "id": "",\n    "timestamp": "",\n    "localTimestamp": "",\n    "localTimezone": "",\n    "callerId": "",\n    "serviceUrl": "",\n    "channelId": "",\n    "from": {},\n    "conversation": {\n      "isGroup": false,\n      "conversationType": "",\n      "tenantId": "",\n      "id": "",\n      "name": "",\n      "aadObjectId": "",\n      "role": ""\n    },\n    "recipient": {},\n    "textFormat": "",\n    "attachmentLayout": "",\n    "membersAdded": [\n      {}\n    ],\n    "membersRemoved": [\n      {}\n    ],\n    "reactionsAdded": [\n      {\n        "type": ""\n      }\n    ],\n    "reactionsRemoved": [\n      {}\n    ],\n    "topicName": "",\n    "historyDisclosed": false,\n    "locale": "",\n    "text": "",\n    "speak": "",\n    "inputHint": "",\n    "summary": "",\n    "suggestedActions": {\n      "to": [],\n      "actions": [\n        {\n          "type": "",\n          "title": "",\n          "image": "",\n          "imageAltText": "",\n          "text": "",\n          "displayText": "",\n          "value": {},\n          "channelData": {}\n        }\n      ]\n    },\n    "attachments": [\n      {\n        "contentType": "",\n        "contentUrl": "",\n        "content": {},\n        "name": "",\n        "thumbnailUrl": ""\n      }\n    ],\n    "entities": [\n      {\n        "type": ""\n      }\n    ],\n    "channelData": {},\n    "action": "",\n    "replyToId": "",\n    "label": "",\n    "valueType": "",\n    "value": {},\n    "name": "",\n    "relatesTo": {\n      "activityId": "",\n      "user": {},\n      "bot": {},\n      "conversation": {},\n      "channelId": "",\n      "serviceUrl": "",\n      "locale": ""\n    },\n    "code": "",\n    "expiration": "",\n    "importance": "",\n    "deliveryMode": "",\n    "listenFor": [],\n    "textHighlights": [\n      {\n        "text": "",\n        "occurrence": 0\n      }\n    ],\n    "semanticAction": {\n      "state": "",\n      "id": "",\n      "entities": {}\n    }\n  },\n  "channelData": {}\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"isGroup\": false,\n  \"bot\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"members\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"tenantId\": \"\",\n  \"activity\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"timestamp\": \"\",\n    \"localTimestamp\": \"\",\n    \"localTimezone\": \"\",\n    \"callerId\": \"\",\n    \"serviceUrl\": \"\",\n    \"channelId\": \"\",\n    \"from\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"recipient\": {},\n    \"textFormat\": \"\",\n    \"attachmentLayout\": \"\",\n    \"membersAdded\": [\n      {}\n    ],\n    \"membersRemoved\": [\n      {}\n    ],\n    \"reactionsAdded\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"reactionsRemoved\": [\n      {}\n    ],\n    \"topicName\": \"\",\n    \"historyDisclosed\": false,\n    \"locale\": \"\",\n    \"text\": \"\",\n    \"speak\": \"\",\n    \"inputHint\": \"\",\n    \"summary\": \"\",\n    \"suggestedActions\": {\n      \"to\": [],\n      \"actions\": [\n        {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      ]\n    },\n    \"attachments\": [\n      {\n        \"contentType\": \"\",\n        \"contentUrl\": \"\",\n        \"content\": {},\n        \"name\": \"\",\n        \"thumbnailUrl\": \"\"\n      }\n    ],\n    \"entities\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"channelData\": {},\n    \"action\": \"\",\n    \"replyToId\": \"\",\n    \"label\": \"\",\n    \"valueType\": \"\",\n    \"value\": {},\n    \"name\": \"\",\n    \"relatesTo\": {\n      \"activityId\": \"\",\n      \"user\": {},\n      \"bot\": {},\n      \"conversation\": {},\n      \"channelId\": \"\",\n      \"serviceUrl\": \"\",\n      \"locale\": \"\"\n    },\n    \"code\": \"\",\n    \"expiration\": \"\",\n    \"importance\": \"\",\n    \"deliveryMode\": \"\",\n    \"listenFor\": [],\n    \"textHighlights\": [\n      {\n        \"text\": \"\",\n        \"occurrence\": 0\n      }\n    ],\n    \"semanticAction\": {\n      \"state\": \"\",\n      \"id\": \"\",\n      \"entities\": {}\n    }\n  },\n  \"channelData\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/conversations")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/conversations',
  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({
  isGroup: false,
  bot: {id: '', name: '', aadObjectId: '', role: ''},
  members: [{}],
  topicName: '',
  tenantId: '',
  activity: {
    type: '',
    id: '',
    timestamp: '',
    localTimestamp: '',
    localTimezone: '',
    callerId: '',
    serviceUrl: '',
    channelId: '',
    from: {},
    conversation: {
      isGroup: false,
      conversationType: '',
      tenantId: '',
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    recipient: {},
    textFormat: '',
    attachmentLayout: '',
    membersAdded: [{}],
    membersRemoved: [{}],
    reactionsAdded: [{type: ''}],
    reactionsRemoved: [{}],
    topicName: '',
    historyDisclosed: false,
    locale: '',
    text: '',
    speak: '',
    inputHint: '',
    summary: '',
    suggestedActions: {
      to: [],
      actions: [
        {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      ]
    },
    attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
    entities: [{type: ''}],
    channelData: {},
    action: '',
    replyToId: '',
    label: '',
    valueType: '',
    value: {},
    name: '',
    relatesTo: {
      activityId: '',
      user: {},
      bot: {},
      conversation: {},
      channelId: '',
      serviceUrl: '',
      locale: ''
    },
    code: '',
    expiration: '',
    importance: '',
    deliveryMode: '',
    listenFor: [],
    textHighlights: [{text: '', occurrence: 0}],
    semanticAction: {state: '', id: '', entities: {}}
  },
  channelData: {}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/conversations',
  headers: {'content-type': 'application/json'},
  body: {
    isGroup: false,
    bot: {id: '', name: '', aadObjectId: '', role: ''},
    members: [{}],
    topicName: '',
    tenantId: '',
    activity: {
      type: '',
      id: '',
      timestamp: '',
      localTimestamp: '',
      localTimezone: '',
      callerId: '',
      serviceUrl: '',
      channelId: '',
      from: {},
      conversation: {
        isGroup: false,
        conversationType: '',
        tenantId: '',
        id: '',
        name: '',
        aadObjectId: '',
        role: ''
      },
      recipient: {},
      textFormat: '',
      attachmentLayout: '',
      membersAdded: [{}],
      membersRemoved: [{}],
      reactionsAdded: [{type: ''}],
      reactionsRemoved: [{}],
      topicName: '',
      historyDisclosed: false,
      locale: '',
      text: '',
      speak: '',
      inputHint: '',
      summary: '',
      suggestedActions: {
        to: [],
        actions: [
          {
            type: '',
            title: '',
            image: '',
            imageAltText: '',
            text: '',
            displayText: '',
            value: {},
            channelData: {}
          }
        ]
      },
      attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
      entities: [{type: ''}],
      channelData: {},
      action: '',
      replyToId: '',
      label: '',
      valueType: '',
      value: {},
      name: '',
      relatesTo: {
        activityId: '',
        user: {},
        bot: {},
        conversation: {},
        channelId: '',
        serviceUrl: '',
        locale: ''
      },
      code: '',
      expiration: '',
      importance: '',
      deliveryMode: '',
      listenFor: [],
      textHighlights: [{text: '', occurrence: 0}],
      semanticAction: {state: '', id: '', entities: {}}
    },
    channelData: {}
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/conversations');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  isGroup: false,
  bot: {
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  members: [
    {}
  ],
  topicName: '',
  tenantId: '',
  activity: {
    type: '',
    id: '',
    timestamp: '',
    localTimestamp: '',
    localTimezone: '',
    callerId: '',
    serviceUrl: '',
    channelId: '',
    from: {},
    conversation: {
      isGroup: false,
      conversationType: '',
      tenantId: '',
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    recipient: {},
    textFormat: '',
    attachmentLayout: '',
    membersAdded: [
      {}
    ],
    membersRemoved: [
      {}
    ],
    reactionsAdded: [
      {
        type: ''
      }
    ],
    reactionsRemoved: [
      {}
    ],
    topicName: '',
    historyDisclosed: false,
    locale: '',
    text: '',
    speak: '',
    inputHint: '',
    summary: '',
    suggestedActions: {
      to: [],
      actions: [
        {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      ]
    },
    attachments: [
      {
        contentType: '',
        contentUrl: '',
        content: {},
        name: '',
        thumbnailUrl: ''
      }
    ],
    entities: [
      {
        type: ''
      }
    ],
    channelData: {},
    action: '',
    replyToId: '',
    label: '',
    valueType: '',
    value: {},
    name: '',
    relatesTo: {
      activityId: '',
      user: {},
      bot: {},
      conversation: {},
      channelId: '',
      serviceUrl: '',
      locale: ''
    },
    code: '',
    expiration: '',
    importance: '',
    deliveryMode: '',
    listenFor: [],
    textHighlights: [
      {
        text: '',
        occurrence: 0
      }
    ],
    semanticAction: {
      state: '',
      id: '',
      entities: {}
    }
  },
  channelData: {}
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/conversations',
  headers: {'content-type': 'application/json'},
  data: {
    isGroup: false,
    bot: {id: '', name: '', aadObjectId: '', role: ''},
    members: [{}],
    topicName: '',
    tenantId: '',
    activity: {
      type: '',
      id: '',
      timestamp: '',
      localTimestamp: '',
      localTimezone: '',
      callerId: '',
      serviceUrl: '',
      channelId: '',
      from: {},
      conversation: {
        isGroup: false,
        conversationType: '',
        tenantId: '',
        id: '',
        name: '',
        aadObjectId: '',
        role: ''
      },
      recipient: {},
      textFormat: '',
      attachmentLayout: '',
      membersAdded: [{}],
      membersRemoved: [{}],
      reactionsAdded: [{type: ''}],
      reactionsRemoved: [{}],
      topicName: '',
      historyDisclosed: false,
      locale: '',
      text: '',
      speak: '',
      inputHint: '',
      summary: '',
      suggestedActions: {
        to: [],
        actions: [
          {
            type: '',
            title: '',
            image: '',
            imageAltText: '',
            text: '',
            displayText: '',
            value: {},
            channelData: {}
          }
        ]
      },
      attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
      entities: [{type: ''}],
      channelData: {},
      action: '',
      replyToId: '',
      label: '',
      valueType: '',
      value: {},
      name: '',
      relatesTo: {
        activityId: '',
        user: {},
        bot: {},
        conversation: {},
        channelId: '',
        serviceUrl: '',
        locale: ''
      },
      code: '',
      expiration: '',
      importance: '',
      deliveryMode: '',
      listenFor: [],
      textHighlights: [{text: '', occurrence: 0}],
      semanticAction: {state: '', id: '', entities: {}}
    },
    channelData: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/conversations';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"isGroup":false,"bot":{"id":"","name":"","aadObjectId":"","role":""},"members":[{}],"topicName":"","tenantId":"","activity":{"type":"","id":"","timestamp":"","localTimestamp":"","localTimezone":"","callerId":"","serviceUrl":"","channelId":"","from":{},"conversation":{"isGroup":false,"conversationType":"","tenantId":"","id":"","name":"","aadObjectId":"","role":""},"recipient":{},"textFormat":"","attachmentLayout":"","membersAdded":[{}],"membersRemoved":[{}],"reactionsAdded":[{"type":""}],"reactionsRemoved":[{}],"topicName":"","historyDisclosed":false,"locale":"","text":"","speak":"","inputHint":"","summary":"","suggestedActions":{"to":[],"actions":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}]},"attachments":[{"contentType":"","contentUrl":"","content":{},"name":"","thumbnailUrl":""}],"entities":[{"type":""}],"channelData":{},"action":"","replyToId":"","label":"","valueType":"","value":{},"name":"","relatesTo":{"activityId":"","user":{},"bot":{},"conversation":{},"channelId":"","serviceUrl":"","locale":""},"code":"","expiration":"","importance":"","deliveryMode":"","listenFor":[],"textHighlights":[{"text":"","occurrence":0}],"semanticAction":{"state":"","id":"","entities":{}}},"channelData":{}}'
};

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 = @{ @"isGroup": @NO,
                              @"bot": @{ @"id": @"", @"name": @"", @"aadObjectId": @"", @"role": @"" },
                              @"members": @[ @{  } ],
                              @"topicName": @"",
                              @"tenantId": @"",
                              @"activity": @{ @"type": @"", @"id": @"", @"timestamp": @"", @"localTimestamp": @"", @"localTimezone": @"", @"callerId": @"", @"serviceUrl": @"", @"channelId": @"", @"from": @{  }, @"conversation": @{ @"isGroup": @NO, @"conversationType": @"", @"tenantId": @"", @"id": @"", @"name": @"", @"aadObjectId": @"", @"role": @"" }, @"recipient": @{  }, @"textFormat": @"", @"attachmentLayout": @"", @"membersAdded": @[ @{  } ], @"membersRemoved": @[ @{  } ], @"reactionsAdded": @[ @{ @"type": @"" } ], @"reactionsRemoved": @[ @{  } ], @"topicName": @"", @"historyDisclosed": @NO, @"locale": @"", @"text": @"", @"speak": @"", @"inputHint": @"", @"summary": @"", @"suggestedActions": @{ @"to": @[  ], @"actions": @[ @{ @"type": @"", @"title": @"", @"image": @"", @"imageAltText": @"", @"text": @"", @"displayText": @"", @"value": @{  }, @"channelData": @{  } } ] }, @"attachments": @[ @{ @"contentType": @"", @"contentUrl": @"", @"content": @{  }, @"name": @"", @"thumbnailUrl": @"" } ], @"entities": @[ @{ @"type": @"" } ], @"channelData": @{  }, @"action": @"", @"replyToId": @"", @"label": @"", @"valueType": @"", @"value": @{  }, @"name": @"", @"relatesTo": @{ @"activityId": @"", @"user": @{  }, @"bot": @{  }, @"conversation": @{  }, @"channelId": @"", @"serviceUrl": @"", @"locale": @"" }, @"code": @"", @"expiration": @"", @"importance": @"", @"deliveryMode": @"", @"listenFor": @[  ], @"textHighlights": @[ @{ @"text": @"", @"occurrence": @0 } ], @"semanticAction": @{ @"state": @"", @"id": @"", @"entities": @{  } } },
                              @"channelData": @{  } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/conversations"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/conversations" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"isGroup\": false,\n  \"bot\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"members\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"tenantId\": \"\",\n  \"activity\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"timestamp\": \"\",\n    \"localTimestamp\": \"\",\n    \"localTimezone\": \"\",\n    \"callerId\": \"\",\n    \"serviceUrl\": \"\",\n    \"channelId\": \"\",\n    \"from\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"recipient\": {},\n    \"textFormat\": \"\",\n    \"attachmentLayout\": \"\",\n    \"membersAdded\": [\n      {}\n    ],\n    \"membersRemoved\": [\n      {}\n    ],\n    \"reactionsAdded\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"reactionsRemoved\": [\n      {}\n    ],\n    \"topicName\": \"\",\n    \"historyDisclosed\": false,\n    \"locale\": \"\",\n    \"text\": \"\",\n    \"speak\": \"\",\n    \"inputHint\": \"\",\n    \"summary\": \"\",\n    \"suggestedActions\": {\n      \"to\": [],\n      \"actions\": [\n        {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      ]\n    },\n    \"attachments\": [\n      {\n        \"contentType\": \"\",\n        \"contentUrl\": \"\",\n        \"content\": {},\n        \"name\": \"\",\n        \"thumbnailUrl\": \"\"\n      }\n    ],\n    \"entities\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"channelData\": {},\n    \"action\": \"\",\n    \"replyToId\": \"\",\n    \"label\": \"\",\n    \"valueType\": \"\",\n    \"value\": {},\n    \"name\": \"\",\n    \"relatesTo\": {\n      \"activityId\": \"\",\n      \"user\": {},\n      \"bot\": {},\n      \"conversation\": {},\n      \"channelId\": \"\",\n      \"serviceUrl\": \"\",\n      \"locale\": \"\"\n    },\n    \"code\": \"\",\n    \"expiration\": \"\",\n    \"importance\": \"\",\n    \"deliveryMode\": \"\",\n    \"listenFor\": [],\n    \"textHighlights\": [\n      {\n        \"text\": \"\",\n        \"occurrence\": 0\n      }\n    ],\n    \"semanticAction\": {\n      \"state\": \"\",\n      \"id\": \"\",\n      \"entities\": {}\n    }\n  },\n  \"channelData\": {}\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/conversations",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'isGroup' => null,
    'bot' => [
        'id' => '',
        'name' => '',
        'aadObjectId' => '',
        'role' => ''
    ],
    'members' => [
        [
                
        ]
    ],
    'topicName' => '',
    'tenantId' => '',
    'activity' => [
        'type' => '',
        'id' => '',
        'timestamp' => '',
        'localTimestamp' => '',
        'localTimezone' => '',
        'callerId' => '',
        'serviceUrl' => '',
        'channelId' => '',
        'from' => [
                
        ],
        'conversation' => [
                'isGroup' => null,
                'conversationType' => '',
                'tenantId' => '',
                'id' => '',
                'name' => '',
                'aadObjectId' => '',
                'role' => ''
        ],
        'recipient' => [
                
        ],
        'textFormat' => '',
        'attachmentLayout' => '',
        'membersAdded' => [
                [
                                
                ]
        ],
        'membersRemoved' => [
                [
                                
                ]
        ],
        'reactionsAdded' => [
                [
                                'type' => ''
                ]
        ],
        'reactionsRemoved' => [
                [
                                
                ]
        ],
        'topicName' => '',
        'historyDisclosed' => null,
        'locale' => '',
        'text' => '',
        'speak' => '',
        'inputHint' => '',
        'summary' => '',
        'suggestedActions' => [
                'to' => [
                                
                ],
                'actions' => [
                                [
                                                                'type' => '',
                                                                'title' => '',
                                                                'image' => '',
                                                                'imageAltText' => '',
                                                                'text' => '',
                                                                'displayText' => '',
                                                                'value' => [
                                                                                                                                
                                                                ],
                                                                'channelData' => [
                                                                                                                                
                                                                ]
                                ]
                ]
        ],
        'attachments' => [
                [
                                'contentType' => '',
                                'contentUrl' => '',
                                'content' => [
                                                                
                                ],
                                'name' => '',
                                'thumbnailUrl' => ''
                ]
        ],
        'entities' => [
                [
                                'type' => ''
                ]
        ],
        'channelData' => [
                
        ],
        'action' => '',
        'replyToId' => '',
        'label' => '',
        'valueType' => '',
        'value' => [
                
        ],
        'name' => '',
        'relatesTo' => [
                'activityId' => '',
                'user' => [
                                
                ],
                'bot' => [
                                
                ],
                'conversation' => [
                                
                ],
                'channelId' => '',
                'serviceUrl' => '',
                'locale' => ''
        ],
        'code' => '',
        'expiration' => '',
        'importance' => '',
        'deliveryMode' => '',
        'listenFor' => [
                
        ],
        'textHighlights' => [
                [
                                'text' => '',
                                'occurrence' => 0
                ]
        ],
        'semanticAction' => [
                'state' => '',
                'id' => '',
                'entities' => [
                                
                ]
        ]
    ],
    'channelData' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/conversations', [
  'body' => '{
  "isGroup": false,
  "bot": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "members": [
    {}
  ],
  "topicName": "",
  "tenantId": "",
  "activity": {
    "type": "",
    "id": "",
    "timestamp": "",
    "localTimestamp": "",
    "localTimezone": "",
    "callerId": "",
    "serviceUrl": "",
    "channelId": "",
    "from": {},
    "conversation": {
      "isGroup": false,
      "conversationType": "",
      "tenantId": "",
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "recipient": {},
    "textFormat": "",
    "attachmentLayout": "",
    "membersAdded": [
      {}
    ],
    "membersRemoved": [
      {}
    ],
    "reactionsAdded": [
      {
        "type": ""
      }
    ],
    "reactionsRemoved": [
      {}
    ],
    "topicName": "",
    "historyDisclosed": false,
    "locale": "",
    "text": "",
    "speak": "",
    "inputHint": "",
    "summary": "",
    "suggestedActions": {
      "to": [],
      "actions": [
        {
          "type": "",
          "title": "",
          "image": "",
          "imageAltText": "",
          "text": "",
          "displayText": "",
          "value": {},
          "channelData": {}
        }
      ]
    },
    "attachments": [
      {
        "contentType": "",
        "contentUrl": "",
        "content": {},
        "name": "",
        "thumbnailUrl": ""
      }
    ],
    "entities": [
      {
        "type": ""
      }
    ],
    "channelData": {},
    "action": "",
    "replyToId": "",
    "label": "",
    "valueType": "",
    "value": {},
    "name": "",
    "relatesTo": {
      "activityId": "",
      "user": {},
      "bot": {},
      "conversation": {},
      "channelId": "",
      "serviceUrl": "",
      "locale": ""
    },
    "code": "",
    "expiration": "",
    "importance": "",
    "deliveryMode": "",
    "listenFor": [],
    "textHighlights": [
      {
        "text": "",
        "occurrence": 0
      }
    ],
    "semanticAction": {
      "state": "",
      "id": "",
      "entities": {}
    }
  },
  "channelData": {}
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/conversations');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'isGroup' => null,
  'bot' => [
    'id' => '',
    'name' => '',
    'aadObjectId' => '',
    'role' => ''
  ],
  'members' => [
    [
        
    ]
  ],
  'topicName' => '',
  'tenantId' => '',
  'activity' => [
    'type' => '',
    'id' => '',
    'timestamp' => '',
    'localTimestamp' => '',
    'localTimezone' => '',
    'callerId' => '',
    'serviceUrl' => '',
    'channelId' => '',
    'from' => [
        
    ],
    'conversation' => [
        'isGroup' => null,
        'conversationType' => '',
        'tenantId' => '',
        'id' => '',
        'name' => '',
        'aadObjectId' => '',
        'role' => ''
    ],
    'recipient' => [
        
    ],
    'textFormat' => '',
    'attachmentLayout' => '',
    'membersAdded' => [
        [
                
        ]
    ],
    'membersRemoved' => [
        [
                
        ]
    ],
    'reactionsAdded' => [
        [
                'type' => ''
        ]
    ],
    'reactionsRemoved' => [
        [
                
        ]
    ],
    'topicName' => '',
    'historyDisclosed' => null,
    'locale' => '',
    'text' => '',
    'speak' => '',
    'inputHint' => '',
    'summary' => '',
    'suggestedActions' => [
        'to' => [
                
        ],
        'actions' => [
                [
                                'type' => '',
                                'title' => '',
                                'image' => '',
                                'imageAltText' => '',
                                'text' => '',
                                'displayText' => '',
                                'value' => [
                                                                
                                ],
                                'channelData' => [
                                                                
                                ]
                ]
        ]
    ],
    'attachments' => [
        [
                'contentType' => '',
                'contentUrl' => '',
                'content' => [
                                
                ],
                'name' => '',
                'thumbnailUrl' => ''
        ]
    ],
    'entities' => [
        [
                'type' => ''
        ]
    ],
    'channelData' => [
        
    ],
    'action' => '',
    'replyToId' => '',
    'label' => '',
    'valueType' => '',
    'value' => [
        
    ],
    'name' => '',
    'relatesTo' => [
        'activityId' => '',
        'user' => [
                
        ],
        'bot' => [
                
        ],
        'conversation' => [
                
        ],
        'channelId' => '',
        'serviceUrl' => '',
        'locale' => ''
    ],
    'code' => '',
    'expiration' => '',
    'importance' => '',
    'deliveryMode' => '',
    'listenFor' => [
        
    ],
    'textHighlights' => [
        [
                'text' => '',
                'occurrence' => 0
        ]
    ],
    'semanticAction' => [
        'state' => '',
        'id' => '',
        'entities' => [
                
        ]
    ]
  ],
  'channelData' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'isGroup' => null,
  'bot' => [
    'id' => '',
    'name' => '',
    'aadObjectId' => '',
    'role' => ''
  ],
  'members' => [
    [
        
    ]
  ],
  'topicName' => '',
  'tenantId' => '',
  'activity' => [
    'type' => '',
    'id' => '',
    'timestamp' => '',
    'localTimestamp' => '',
    'localTimezone' => '',
    'callerId' => '',
    'serviceUrl' => '',
    'channelId' => '',
    'from' => [
        
    ],
    'conversation' => [
        'isGroup' => null,
        'conversationType' => '',
        'tenantId' => '',
        'id' => '',
        'name' => '',
        'aadObjectId' => '',
        'role' => ''
    ],
    'recipient' => [
        
    ],
    'textFormat' => '',
    'attachmentLayout' => '',
    'membersAdded' => [
        [
                
        ]
    ],
    'membersRemoved' => [
        [
                
        ]
    ],
    'reactionsAdded' => [
        [
                'type' => ''
        ]
    ],
    'reactionsRemoved' => [
        [
                
        ]
    ],
    'topicName' => '',
    'historyDisclosed' => null,
    'locale' => '',
    'text' => '',
    'speak' => '',
    'inputHint' => '',
    'summary' => '',
    'suggestedActions' => [
        'to' => [
                
        ],
        'actions' => [
                [
                                'type' => '',
                                'title' => '',
                                'image' => '',
                                'imageAltText' => '',
                                'text' => '',
                                'displayText' => '',
                                'value' => [
                                                                
                                ],
                                'channelData' => [
                                                                
                                ]
                ]
        ]
    ],
    'attachments' => [
        [
                'contentType' => '',
                'contentUrl' => '',
                'content' => [
                                
                ],
                'name' => '',
                'thumbnailUrl' => ''
        ]
    ],
    'entities' => [
        [
                'type' => ''
        ]
    ],
    'channelData' => [
        
    ],
    'action' => '',
    'replyToId' => '',
    'label' => '',
    'valueType' => '',
    'value' => [
        
    ],
    'name' => '',
    'relatesTo' => [
        'activityId' => '',
        'user' => [
                
        ],
        'bot' => [
                
        ],
        'conversation' => [
                
        ],
        'channelId' => '',
        'serviceUrl' => '',
        'locale' => ''
    ],
    'code' => '',
    'expiration' => '',
    'importance' => '',
    'deliveryMode' => '',
    'listenFor' => [
        
    ],
    'textHighlights' => [
        [
                'text' => '',
                'occurrence' => 0
        ]
    ],
    'semanticAction' => [
        'state' => '',
        'id' => '',
        'entities' => [
                
        ]
    ]
  ],
  'channelData' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/conversations');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/conversations' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "isGroup": false,
  "bot": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "members": [
    {}
  ],
  "topicName": "",
  "tenantId": "",
  "activity": {
    "type": "",
    "id": "",
    "timestamp": "",
    "localTimestamp": "",
    "localTimezone": "",
    "callerId": "",
    "serviceUrl": "",
    "channelId": "",
    "from": {},
    "conversation": {
      "isGroup": false,
      "conversationType": "",
      "tenantId": "",
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "recipient": {},
    "textFormat": "",
    "attachmentLayout": "",
    "membersAdded": [
      {}
    ],
    "membersRemoved": [
      {}
    ],
    "reactionsAdded": [
      {
        "type": ""
      }
    ],
    "reactionsRemoved": [
      {}
    ],
    "topicName": "",
    "historyDisclosed": false,
    "locale": "",
    "text": "",
    "speak": "",
    "inputHint": "",
    "summary": "",
    "suggestedActions": {
      "to": [],
      "actions": [
        {
          "type": "",
          "title": "",
          "image": "",
          "imageAltText": "",
          "text": "",
          "displayText": "",
          "value": {},
          "channelData": {}
        }
      ]
    },
    "attachments": [
      {
        "contentType": "",
        "contentUrl": "",
        "content": {},
        "name": "",
        "thumbnailUrl": ""
      }
    ],
    "entities": [
      {
        "type": ""
      }
    ],
    "channelData": {},
    "action": "",
    "replyToId": "",
    "label": "",
    "valueType": "",
    "value": {},
    "name": "",
    "relatesTo": {
      "activityId": "",
      "user": {},
      "bot": {},
      "conversation": {},
      "channelId": "",
      "serviceUrl": "",
      "locale": ""
    },
    "code": "",
    "expiration": "",
    "importance": "",
    "deliveryMode": "",
    "listenFor": [],
    "textHighlights": [
      {
        "text": "",
        "occurrence": 0
      }
    ],
    "semanticAction": {
      "state": "",
      "id": "",
      "entities": {}
    }
  },
  "channelData": {}
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/conversations' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "isGroup": false,
  "bot": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "members": [
    {}
  ],
  "topicName": "",
  "tenantId": "",
  "activity": {
    "type": "",
    "id": "",
    "timestamp": "",
    "localTimestamp": "",
    "localTimezone": "",
    "callerId": "",
    "serviceUrl": "",
    "channelId": "",
    "from": {},
    "conversation": {
      "isGroup": false,
      "conversationType": "",
      "tenantId": "",
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "recipient": {},
    "textFormat": "",
    "attachmentLayout": "",
    "membersAdded": [
      {}
    ],
    "membersRemoved": [
      {}
    ],
    "reactionsAdded": [
      {
        "type": ""
      }
    ],
    "reactionsRemoved": [
      {}
    ],
    "topicName": "",
    "historyDisclosed": false,
    "locale": "",
    "text": "",
    "speak": "",
    "inputHint": "",
    "summary": "",
    "suggestedActions": {
      "to": [],
      "actions": [
        {
          "type": "",
          "title": "",
          "image": "",
          "imageAltText": "",
          "text": "",
          "displayText": "",
          "value": {},
          "channelData": {}
        }
      ]
    },
    "attachments": [
      {
        "contentType": "",
        "contentUrl": "",
        "content": {},
        "name": "",
        "thumbnailUrl": ""
      }
    ],
    "entities": [
      {
        "type": ""
      }
    ],
    "channelData": {},
    "action": "",
    "replyToId": "",
    "label": "",
    "valueType": "",
    "value": {},
    "name": "",
    "relatesTo": {
      "activityId": "",
      "user": {},
      "bot": {},
      "conversation": {},
      "channelId": "",
      "serviceUrl": "",
      "locale": ""
    },
    "code": "",
    "expiration": "",
    "importance": "",
    "deliveryMode": "",
    "listenFor": [],
    "textHighlights": [
      {
        "text": "",
        "occurrence": 0
      }
    ],
    "semanticAction": {
      "state": "",
      "id": "",
      "entities": {}
    }
  },
  "channelData": {}
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"isGroup\": false,\n  \"bot\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"members\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"tenantId\": \"\",\n  \"activity\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"timestamp\": \"\",\n    \"localTimestamp\": \"\",\n    \"localTimezone\": \"\",\n    \"callerId\": \"\",\n    \"serviceUrl\": \"\",\n    \"channelId\": \"\",\n    \"from\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"recipient\": {},\n    \"textFormat\": \"\",\n    \"attachmentLayout\": \"\",\n    \"membersAdded\": [\n      {}\n    ],\n    \"membersRemoved\": [\n      {}\n    ],\n    \"reactionsAdded\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"reactionsRemoved\": [\n      {}\n    ],\n    \"topicName\": \"\",\n    \"historyDisclosed\": false,\n    \"locale\": \"\",\n    \"text\": \"\",\n    \"speak\": \"\",\n    \"inputHint\": \"\",\n    \"summary\": \"\",\n    \"suggestedActions\": {\n      \"to\": [],\n      \"actions\": [\n        {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      ]\n    },\n    \"attachments\": [\n      {\n        \"contentType\": \"\",\n        \"contentUrl\": \"\",\n        \"content\": {},\n        \"name\": \"\",\n        \"thumbnailUrl\": \"\"\n      }\n    ],\n    \"entities\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"channelData\": {},\n    \"action\": \"\",\n    \"replyToId\": \"\",\n    \"label\": \"\",\n    \"valueType\": \"\",\n    \"value\": {},\n    \"name\": \"\",\n    \"relatesTo\": {\n      \"activityId\": \"\",\n      \"user\": {},\n      \"bot\": {},\n      \"conversation\": {},\n      \"channelId\": \"\",\n      \"serviceUrl\": \"\",\n      \"locale\": \"\"\n    },\n    \"code\": \"\",\n    \"expiration\": \"\",\n    \"importance\": \"\",\n    \"deliveryMode\": \"\",\n    \"listenFor\": [],\n    \"textHighlights\": [\n      {\n        \"text\": \"\",\n        \"occurrence\": 0\n      }\n    ],\n    \"semanticAction\": {\n      \"state\": \"\",\n      \"id\": \"\",\n      \"entities\": {}\n    }\n  },\n  \"channelData\": {}\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/conversations", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/conversations"

payload = {
    "isGroup": False,
    "bot": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
    },
    "members": [{}],
    "topicName": "",
    "tenantId": "",
    "activity": {
        "type": "",
        "id": "",
        "timestamp": "",
        "localTimestamp": "",
        "localTimezone": "",
        "callerId": "",
        "serviceUrl": "",
        "channelId": "",
        "from": {},
        "conversation": {
            "isGroup": False,
            "conversationType": "",
            "tenantId": "",
            "id": "",
            "name": "",
            "aadObjectId": "",
            "role": ""
        },
        "recipient": {},
        "textFormat": "",
        "attachmentLayout": "",
        "membersAdded": [{}],
        "membersRemoved": [{}],
        "reactionsAdded": [{ "type": "" }],
        "reactionsRemoved": [{}],
        "topicName": "",
        "historyDisclosed": False,
        "locale": "",
        "text": "",
        "speak": "",
        "inputHint": "",
        "summary": "",
        "suggestedActions": {
            "to": [],
            "actions": [
                {
                    "type": "",
                    "title": "",
                    "image": "",
                    "imageAltText": "",
                    "text": "",
                    "displayText": "",
                    "value": {},
                    "channelData": {}
                }
            ]
        },
        "attachments": [
            {
                "contentType": "",
                "contentUrl": "",
                "content": {},
                "name": "",
                "thumbnailUrl": ""
            }
        ],
        "entities": [{ "type": "" }],
        "channelData": {},
        "action": "",
        "replyToId": "",
        "label": "",
        "valueType": "",
        "value": {},
        "name": "",
        "relatesTo": {
            "activityId": "",
            "user": {},
            "bot": {},
            "conversation": {},
            "channelId": "",
            "serviceUrl": "",
            "locale": ""
        },
        "code": "",
        "expiration": "",
        "importance": "",
        "deliveryMode": "",
        "listenFor": [],
        "textHighlights": [
            {
                "text": "",
                "occurrence": 0
            }
        ],
        "semanticAction": {
            "state": "",
            "id": "",
            "entities": {}
        }
    },
    "channelData": {}
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/conversations"

payload <- "{\n  \"isGroup\": false,\n  \"bot\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"members\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"tenantId\": \"\",\n  \"activity\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"timestamp\": \"\",\n    \"localTimestamp\": \"\",\n    \"localTimezone\": \"\",\n    \"callerId\": \"\",\n    \"serviceUrl\": \"\",\n    \"channelId\": \"\",\n    \"from\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"recipient\": {},\n    \"textFormat\": \"\",\n    \"attachmentLayout\": \"\",\n    \"membersAdded\": [\n      {}\n    ],\n    \"membersRemoved\": [\n      {}\n    ],\n    \"reactionsAdded\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"reactionsRemoved\": [\n      {}\n    ],\n    \"topicName\": \"\",\n    \"historyDisclosed\": false,\n    \"locale\": \"\",\n    \"text\": \"\",\n    \"speak\": \"\",\n    \"inputHint\": \"\",\n    \"summary\": \"\",\n    \"suggestedActions\": {\n      \"to\": [],\n      \"actions\": [\n        {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      ]\n    },\n    \"attachments\": [\n      {\n        \"contentType\": \"\",\n        \"contentUrl\": \"\",\n        \"content\": {},\n        \"name\": \"\",\n        \"thumbnailUrl\": \"\"\n      }\n    ],\n    \"entities\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"channelData\": {},\n    \"action\": \"\",\n    \"replyToId\": \"\",\n    \"label\": \"\",\n    \"valueType\": \"\",\n    \"value\": {},\n    \"name\": \"\",\n    \"relatesTo\": {\n      \"activityId\": \"\",\n      \"user\": {},\n      \"bot\": {},\n      \"conversation\": {},\n      \"channelId\": \"\",\n      \"serviceUrl\": \"\",\n      \"locale\": \"\"\n    },\n    \"code\": \"\",\n    \"expiration\": \"\",\n    \"importance\": \"\",\n    \"deliveryMode\": \"\",\n    \"listenFor\": [],\n    \"textHighlights\": [\n      {\n        \"text\": \"\",\n        \"occurrence\": 0\n      }\n    ],\n    \"semanticAction\": {\n      \"state\": \"\",\n      \"id\": \"\",\n      \"entities\": {}\n    }\n  },\n  \"channelData\": {}\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/conversations")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"isGroup\": false,\n  \"bot\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"members\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"tenantId\": \"\",\n  \"activity\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"timestamp\": \"\",\n    \"localTimestamp\": \"\",\n    \"localTimezone\": \"\",\n    \"callerId\": \"\",\n    \"serviceUrl\": \"\",\n    \"channelId\": \"\",\n    \"from\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"recipient\": {},\n    \"textFormat\": \"\",\n    \"attachmentLayout\": \"\",\n    \"membersAdded\": [\n      {}\n    ],\n    \"membersRemoved\": [\n      {}\n    ],\n    \"reactionsAdded\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"reactionsRemoved\": [\n      {}\n    ],\n    \"topicName\": \"\",\n    \"historyDisclosed\": false,\n    \"locale\": \"\",\n    \"text\": \"\",\n    \"speak\": \"\",\n    \"inputHint\": \"\",\n    \"summary\": \"\",\n    \"suggestedActions\": {\n      \"to\": [],\n      \"actions\": [\n        {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      ]\n    },\n    \"attachments\": [\n      {\n        \"contentType\": \"\",\n        \"contentUrl\": \"\",\n        \"content\": {},\n        \"name\": \"\",\n        \"thumbnailUrl\": \"\"\n      }\n    ],\n    \"entities\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"channelData\": {},\n    \"action\": \"\",\n    \"replyToId\": \"\",\n    \"label\": \"\",\n    \"valueType\": \"\",\n    \"value\": {},\n    \"name\": \"\",\n    \"relatesTo\": {\n      \"activityId\": \"\",\n      \"user\": {},\n      \"bot\": {},\n      \"conversation\": {},\n      \"channelId\": \"\",\n      \"serviceUrl\": \"\",\n      \"locale\": \"\"\n    },\n    \"code\": \"\",\n    \"expiration\": \"\",\n    \"importance\": \"\",\n    \"deliveryMode\": \"\",\n    \"listenFor\": [],\n    \"textHighlights\": [\n      {\n        \"text\": \"\",\n        \"occurrence\": 0\n      }\n    ],\n    \"semanticAction\": {\n      \"state\": \"\",\n      \"id\": \"\",\n      \"entities\": {}\n    }\n  },\n  \"channelData\": {}\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/conversations') do |req|
  req.body = "{\n  \"isGroup\": false,\n  \"bot\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"members\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"tenantId\": \"\",\n  \"activity\": {\n    \"type\": \"\",\n    \"id\": \"\",\n    \"timestamp\": \"\",\n    \"localTimestamp\": \"\",\n    \"localTimezone\": \"\",\n    \"callerId\": \"\",\n    \"serviceUrl\": \"\",\n    \"channelId\": \"\",\n    \"from\": {},\n    \"conversation\": {\n      \"isGroup\": false,\n      \"conversationType\": \"\",\n      \"tenantId\": \"\",\n      \"id\": \"\",\n      \"name\": \"\",\n      \"aadObjectId\": \"\",\n      \"role\": \"\"\n    },\n    \"recipient\": {},\n    \"textFormat\": \"\",\n    \"attachmentLayout\": \"\",\n    \"membersAdded\": [\n      {}\n    ],\n    \"membersRemoved\": [\n      {}\n    ],\n    \"reactionsAdded\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"reactionsRemoved\": [\n      {}\n    ],\n    \"topicName\": \"\",\n    \"historyDisclosed\": false,\n    \"locale\": \"\",\n    \"text\": \"\",\n    \"speak\": \"\",\n    \"inputHint\": \"\",\n    \"summary\": \"\",\n    \"suggestedActions\": {\n      \"to\": [],\n      \"actions\": [\n        {\n          \"type\": \"\",\n          \"title\": \"\",\n          \"image\": \"\",\n          \"imageAltText\": \"\",\n          \"text\": \"\",\n          \"displayText\": \"\",\n          \"value\": {},\n          \"channelData\": {}\n        }\n      ]\n    },\n    \"attachments\": [\n      {\n        \"contentType\": \"\",\n        \"contentUrl\": \"\",\n        \"content\": {},\n        \"name\": \"\",\n        \"thumbnailUrl\": \"\"\n      }\n    ],\n    \"entities\": [\n      {\n        \"type\": \"\"\n      }\n    ],\n    \"channelData\": {},\n    \"action\": \"\",\n    \"replyToId\": \"\",\n    \"label\": \"\",\n    \"valueType\": \"\",\n    \"value\": {},\n    \"name\": \"\",\n    \"relatesTo\": {\n      \"activityId\": \"\",\n      \"user\": {},\n      \"bot\": {},\n      \"conversation\": {},\n      \"channelId\": \"\",\n      \"serviceUrl\": \"\",\n      \"locale\": \"\"\n    },\n    \"code\": \"\",\n    \"expiration\": \"\",\n    \"importance\": \"\",\n    \"deliveryMode\": \"\",\n    \"listenFor\": [],\n    \"textHighlights\": [\n      {\n        \"text\": \"\",\n        \"occurrence\": 0\n      }\n    ],\n    \"semanticAction\": {\n      \"state\": \"\",\n      \"id\": \"\",\n      \"entities\": {}\n    }\n  },\n  \"channelData\": {}\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/conversations";

    let payload = json!({
        "isGroup": false,
        "bot": json!({
            "id": "",
            "name": "",
            "aadObjectId": "",
            "role": ""
        }),
        "members": (json!({})),
        "topicName": "",
        "tenantId": "",
        "activity": json!({
            "type": "",
            "id": "",
            "timestamp": "",
            "localTimestamp": "",
            "localTimezone": "",
            "callerId": "",
            "serviceUrl": "",
            "channelId": "",
            "from": json!({}),
            "conversation": json!({
                "isGroup": false,
                "conversationType": "",
                "tenantId": "",
                "id": "",
                "name": "",
                "aadObjectId": "",
                "role": ""
            }),
            "recipient": json!({}),
            "textFormat": "",
            "attachmentLayout": "",
            "membersAdded": (json!({})),
            "membersRemoved": (json!({})),
            "reactionsAdded": (json!({"type": ""})),
            "reactionsRemoved": (json!({})),
            "topicName": "",
            "historyDisclosed": false,
            "locale": "",
            "text": "",
            "speak": "",
            "inputHint": "",
            "summary": "",
            "suggestedActions": json!({
                "to": (),
                "actions": (
                    json!({
                        "type": "",
                        "title": "",
                        "image": "",
                        "imageAltText": "",
                        "text": "",
                        "displayText": "",
                        "value": json!({}),
                        "channelData": json!({})
                    })
                )
            }),
            "attachments": (
                json!({
                    "contentType": "",
                    "contentUrl": "",
                    "content": json!({}),
                    "name": "",
                    "thumbnailUrl": ""
                })
            ),
            "entities": (json!({"type": ""})),
            "channelData": json!({}),
            "action": "",
            "replyToId": "",
            "label": "",
            "valueType": "",
            "value": json!({}),
            "name": "",
            "relatesTo": json!({
                "activityId": "",
                "user": json!({}),
                "bot": json!({}),
                "conversation": json!({}),
                "channelId": "",
                "serviceUrl": "",
                "locale": ""
            }),
            "code": "",
            "expiration": "",
            "importance": "",
            "deliveryMode": "",
            "listenFor": (),
            "textHighlights": (
                json!({
                    "text": "",
                    "occurrence": 0
                })
            ),
            "semanticAction": json!({
                "state": "",
                "id": "",
                "entities": json!({})
            })
        }),
        "channelData": json!({})
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/conversations \
  --header 'content-type: application/json' \
  --data '{
  "isGroup": false,
  "bot": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "members": [
    {}
  ],
  "topicName": "",
  "tenantId": "",
  "activity": {
    "type": "",
    "id": "",
    "timestamp": "",
    "localTimestamp": "",
    "localTimezone": "",
    "callerId": "",
    "serviceUrl": "",
    "channelId": "",
    "from": {},
    "conversation": {
      "isGroup": false,
      "conversationType": "",
      "tenantId": "",
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "recipient": {},
    "textFormat": "",
    "attachmentLayout": "",
    "membersAdded": [
      {}
    ],
    "membersRemoved": [
      {}
    ],
    "reactionsAdded": [
      {
        "type": ""
      }
    ],
    "reactionsRemoved": [
      {}
    ],
    "topicName": "",
    "historyDisclosed": false,
    "locale": "",
    "text": "",
    "speak": "",
    "inputHint": "",
    "summary": "",
    "suggestedActions": {
      "to": [],
      "actions": [
        {
          "type": "",
          "title": "",
          "image": "",
          "imageAltText": "",
          "text": "",
          "displayText": "",
          "value": {},
          "channelData": {}
        }
      ]
    },
    "attachments": [
      {
        "contentType": "",
        "contentUrl": "",
        "content": {},
        "name": "",
        "thumbnailUrl": ""
      }
    ],
    "entities": [
      {
        "type": ""
      }
    ],
    "channelData": {},
    "action": "",
    "replyToId": "",
    "label": "",
    "valueType": "",
    "value": {},
    "name": "",
    "relatesTo": {
      "activityId": "",
      "user": {},
      "bot": {},
      "conversation": {},
      "channelId": "",
      "serviceUrl": "",
      "locale": ""
    },
    "code": "",
    "expiration": "",
    "importance": "",
    "deliveryMode": "",
    "listenFor": [],
    "textHighlights": [
      {
        "text": "",
        "occurrence": 0
      }
    ],
    "semanticAction": {
      "state": "",
      "id": "",
      "entities": {}
    }
  },
  "channelData": {}
}'
echo '{
  "isGroup": false,
  "bot": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "members": [
    {}
  ],
  "topicName": "",
  "tenantId": "",
  "activity": {
    "type": "",
    "id": "",
    "timestamp": "",
    "localTimestamp": "",
    "localTimezone": "",
    "callerId": "",
    "serviceUrl": "",
    "channelId": "",
    "from": {},
    "conversation": {
      "isGroup": false,
      "conversationType": "",
      "tenantId": "",
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    },
    "recipient": {},
    "textFormat": "",
    "attachmentLayout": "",
    "membersAdded": [
      {}
    ],
    "membersRemoved": [
      {}
    ],
    "reactionsAdded": [
      {
        "type": ""
      }
    ],
    "reactionsRemoved": [
      {}
    ],
    "topicName": "",
    "historyDisclosed": false,
    "locale": "",
    "text": "",
    "speak": "",
    "inputHint": "",
    "summary": "",
    "suggestedActions": {
      "to": [],
      "actions": [
        {
          "type": "",
          "title": "",
          "image": "",
          "imageAltText": "",
          "text": "",
          "displayText": "",
          "value": {},
          "channelData": {}
        }
      ]
    },
    "attachments": [
      {
        "contentType": "",
        "contentUrl": "",
        "content": {},
        "name": "",
        "thumbnailUrl": ""
      }
    ],
    "entities": [
      {
        "type": ""
      }
    ],
    "channelData": {},
    "action": "",
    "replyToId": "",
    "label": "",
    "valueType": "",
    "value": {},
    "name": "",
    "relatesTo": {
      "activityId": "",
      "user": {},
      "bot": {},
      "conversation": {},
      "channelId": "",
      "serviceUrl": "",
      "locale": ""
    },
    "code": "",
    "expiration": "",
    "importance": "",
    "deliveryMode": "",
    "listenFor": [],
    "textHighlights": [
      {
        "text": "",
        "occurrence": 0
      }
    ],
    "semanticAction": {
      "state": "",
      "id": "",
      "entities": {}
    }
  },
  "channelData": {}
}' |  \
  http POST {{baseUrl}}/v3/conversations \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "isGroup": false,\n  "bot": {\n    "id": "",\n    "name": "",\n    "aadObjectId": "",\n    "role": ""\n  },\n  "members": [\n    {}\n  ],\n  "topicName": "",\n  "tenantId": "",\n  "activity": {\n    "type": "",\n    "id": "",\n    "timestamp": "",\n    "localTimestamp": "",\n    "localTimezone": "",\n    "callerId": "",\n    "serviceUrl": "",\n    "channelId": "",\n    "from": {},\n    "conversation": {\n      "isGroup": false,\n      "conversationType": "",\n      "tenantId": "",\n      "id": "",\n      "name": "",\n      "aadObjectId": "",\n      "role": ""\n    },\n    "recipient": {},\n    "textFormat": "",\n    "attachmentLayout": "",\n    "membersAdded": [\n      {}\n    ],\n    "membersRemoved": [\n      {}\n    ],\n    "reactionsAdded": [\n      {\n        "type": ""\n      }\n    ],\n    "reactionsRemoved": [\n      {}\n    ],\n    "topicName": "",\n    "historyDisclosed": false,\n    "locale": "",\n    "text": "",\n    "speak": "",\n    "inputHint": "",\n    "summary": "",\n    "suggestedActions": {\n      "to": [],\n      "actions": [\n        {\n          "type": "",\n          "title": "",\n          "image": "",\n          "imageAltText": "",\n          "text": "",\n          "displayText": "",\n          "value": {},\n          "channelData": {}\n        }\n      ]\n    },\n    "attachments": [\n      {\n        "contentType": "",\n        "contentUrl": "",\n        "content": {},\n        "name": "",\n        "thumbnailUrl": ""\n      }\n    ],\n    "entities": [\n      {\n        "type": ""\n      }\n    ],\n    "channelData": {},\n    "action": "",\n    "replyToId": "",\n    "label": "",\n    "valueType": "",\n    "value": {},\n    "name": "",\n    "relatesTo": {\n      "activityId": "",\n      "user": {},\n      "bot": {},\n      "conversation": {},\n      "channelId": "",\n      "serviceUrl": "",\n      "locale": ""\n    },\n    "code": "",\n    "expiration": "",\n    "importance": "",\n    "deliveryMode": "",\n    "listenFor": [],\n    "textHighlights": [\n      {\n        "text": "",\n        "occurrence": 0\n      }\n    ],\n    "semanticAction": {\n      "state": "",\n      "id": "",\n      "entities": {}\n    }\n  },\n  "channelData": {}\n}' \
  --output-document \
  - {{baseUrl}}/v3/conversations
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "isGroup": false,
  "bot": [
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  ],
  "members": [[]],
  "topicName": "",
  "tenantId": "",
  "activity": [
    "type": "",
    "id": "",
    "timestamp": "",
    "localTimestamp": "",
    "localTimezone": "",
    "callerId": "",
    "serviceUrl": "",
    "channelId": "",
    "from": [],
    "conversation": [
      "isGroup": false,
      "conversationType": "",
      "tenantId": "",
      "id": "",
      "name": "",
      "aadObjectId": "",
      "role": ""
    ],
    "recipient": [],
    "textFormat": "",
    "attachmentLayout": "",
    "membersAdded": [[]],
    "membersRemoved": [[]],
    "reactionsAdded": [["type": ""]],
    "reactionsRemoved": [[]],
    "topicName": "",
    "historyDisclosed": false,
    "locale": "",
    "text": "",
    "speak": "",
    "inputHint": "",
    "summary": "",
    "suggestedActions": [
      "to": [],
      "actions": [
        [
          "type": "",
          "title": "",
          "image": "",
          "imageAltText": "",
          "text": "",
          "displayText": "",
          "value": [],
          "channelData": []
        ]
      ]
    ],
    "attachments": [
      [
        "contentType": "",
        "contentUrl": "",
        "content": [],
        "name": "",
        "thumbnailUrl": ""
      ]
    ],
    "entities": [["type": ""]],
    "channelData": [],
    "action": "",
    "replyToId": "",
    "label": "",
    "valueType": "",
    "value": [],
    "name": "",
    "relatesTo": [
      "activityId": "",
      "user": [],
      "bot": [],
      "conversation": [],
      "channelId": "",
      "serviceUrl": "",
      "locale": ""
    ],
    "code": "",
    "expiration": "",
    "importance": "",
    "deliveryMode": "",
    "listenFor": [],
    "textHighlights": [
      [
        "text": "",
        "occurrence": 0
      ]
    ],
    "semanticAction": [
      "state": "",
      "id": "",
      "entities": []
    ]
  ],
  "channelData": []
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/conversations")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DeleteActivity
{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId
QUERY PARAMS

conversationId
activityId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId")
require "http/client"

url = "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/v3/conversations/:conversationId/activities/:activityId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"))
    .method("DELETE", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/conversations/:conversationId/activities/:activityId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId');

echo $response->getBody();
setUrl('{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/v3/conversations/:conversationId/activities/:activityId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/v3/conversations/:conversationId/activities/:activityId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/v3/conversations/:conversationId/activities/:activityId
http DELETE {{baseUrl}}/v3/conversations/:conversationId/activities/:activityId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/v3/conversations/:conversationId/activities/:activityId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DeleteConversationMember
{{baseUrl}}/v3/conversations/:conversationId/members/:memberId
QUERY PARAMS

conversationId
memberId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId")
require "http/client"

url = "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId"

response = HTTP::Client.delete url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Delete,
    RequestUri = new Uri("{{baseUrl}}/v3/conversations/:conversationId/members/:memberId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3/conversations/:conversationId/members/:memberId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId"

	req, _ := http.NewRequest("DELETE", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/v3/conversations/:conversationId/members/:memberId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/conversations/:conversationId/members/:memberId"))
    .method("DELETE", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/conversations/:conversationId/members/:memberId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/v3/conversations/:conversationId/members/:memberId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('DELETE', '{{baseUrl}}/v3/conversations/:conversationId/members/:memberId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/v3/conversations/:conversationId/members/:memberId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/conversations/:conversationId/members/:memberId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v3/conversations/:conversationId/members/:memberId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v3/conversations/:conversationId/members/:memberId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/conversations/:conversationId/members/:memberId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/v3/conversations/:conversationId/members/:memberId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/v3/conversations/:conversationId/members/:memberId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/v3/conversations/:conversationId/members/:memberId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/conversations/:conversationId/members/:memberId';
const options = {method: 'DELETE'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/conversations/:conversationId/members/:memberId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"DELETE"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/v3/conversations/:conversationId/members/:memberId');

echo $response->getBody();
setUrl('{{baseUrl}}/v3/conversations/:conversationId/members/:memberId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v3/conversations/:conversationId/members/:memberId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/conversations/:conversationId/members/:memberId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/conversations/:conversationId/members/:memberId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/v3/conversations/:conversationId/members/:memberId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/conversations/:conversationId/members/:memberId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/v3/conversations/:conversationId/members/:memberId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/v3/conversations/:conversationId/members/:memberId
http DELETE {{baseUrl}}/v3/conversations/:conversationId/members/:memberId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/v3/conversations/:conversationId/members/:memberId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET GetActivityMembers
{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members
QUERY PARAMS

conversationId
activityId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members")
require "http/client"

url = "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members"

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}}/v3/conversations/:conversationId/activities/:activityId/members"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members"

	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/v3/conversations/:conversationId/activities/:activityId/members HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members"))
    .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}}/v3/conversations/:conversationId/activities/:activityId/members")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members")
  .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}}/v3/conversations/:conversationId/activities/:activityId/members');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members';
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}}/v3/conversations/:conversationId/activities/:activityId/members',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/conversations/:conversationId/activities/:activityId/members',
  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}}/v3/conversations/:conversationId/activities/:activityId/members'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members');

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}}/v3/conversations/:conversationId/activities/:activityId/members'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members';
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}}/v3/conversations/:conversationId/activities/:activityId/members"]
                                                       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}}/v3/conversations/:conversationId/activities/:activityId/members" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members",
  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}}/v3/conversations/:conversationId/activities/:activityId/members');

echo $response->getBody();
setUrl('{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v3/conversations/:conversationId/activities/:activityId/members")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members")

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/v3/conversations/:conversationId/activities/:activityId/members') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members";

    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}}/v3/conversations/:conversationId/activities/:activityId/members
http GET {{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId/members")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET GetConversationMember
{{baseUrl}}/v3/conversations/:conversationId/members/:memberId
QUERY PARAMS

conversationId
memberId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId")
require "http/client"

url = "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId"

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}}/v3/conversations/:conversationId/members/:memberId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3/conversations/:conversationId/members/:memberId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId"

	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/v3/conversations/:conversationId/members/:memberId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/conversations/:conversationId/members/:memberId"))
    .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}}/v3/conversations/:conversationId/members/:memberId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v3/conversations/:conversationId/members/:memberId")
  .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}}/v3/conversations/:conversationId/members/:memberId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v3/conversations/:conversationId/members/:memberId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/conversations/:conversationId/members/:memberId';
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}}/v3/conversations/:conversationId/members/:memberId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v3/conversations/:conversationId/members/:memberId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/conversations/:conversationId/members/:memberId',
  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}}/v3/conversations/:conversationId/members/:memberId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v3/conversations/:conversationId/members/:memberId');

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}}/v3/conversations/:conversationId/members/:memberId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/conversations/:conversationId/members/:memberId';
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}}/v3/conversations/:conversationId/members/:memberId"]
                                                       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}}/v3/conversations/:conversationId/members/:memberId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId",
  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}}/v3/conversations/:conversationId/members/:memberId');

echo $response->getBody();
setUrl('{{baseUrl}}/v3/conversations/:conversationId/members/:memberId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v3/conversations/:conversationId/members/:memberId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/conversations/:conversationId/members/:memberId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/conversations/:conversationId/members/:memberId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v3/conversations/:conversationId/members/:memberId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/conversations/:conversationId/members/:memberId")

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/v3/conversations/:conversationId/members/:memberId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId";

    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}}/v3/conversations/:conversationId/members/:memberId
http GET {{baseUrl}}/v3/conversations/:conversationId/members/:memberId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v3/conversations/:conversationId/members/:memberId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/conversations/:conversationId/members/:memberId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET GetConversationMembers
{{baseUrl}}/v3/conversations/:conversationId/members
QUERY PARAMS

conversationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/conversations/:conversationId/members");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v3/conversations/:conversationId/members")
require "http/client"

url = "{{baseUrl}}/v3/conversations/:conversationId/members"

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}}/v3/conversations/:conversationId/members"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3/conversations/:conversationId/members");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/conversations/:conversationId/members"

	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/v3/conversations/:conversationId/members HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v3/conversations/:conversationId/members")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/conversations/:conversationId/members"))
    .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}}/v3/conversations/:conversationId/members")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v3/conversations/:conversationId/members")
  .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}}/v3/conversations/:conversationId/members');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v3/conversations/:conversationId/members'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/conversations/:conversationId/members';
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}}/v3/conversations/:conversationId/members',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v3/conversations/:conversationId/members")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/conversations/:conversationId/members',
  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}}/v3/conversations/:conversationId/members'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v3/conversations/:conversationId/members');

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}}/v3/conversations/:conversationId/members'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/conversations/:conversationId/members';
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}}/v3/conversations/:conversationId/members"]
                                                       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}}/v3/conversations/:conversationId/members" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/conversations/:conversationId/members",
  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}}/v3/conversations/:conversationId/members');

echo $response->getBody();
setUrl('{{baseUrl}}/v3/conversations/:conversationId/members');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v3/conversations/:conversationId/members');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/conversations/:conversationId/members' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/conversations/:conversationId/members' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v3/conversations/:conversationId/members")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/conversations/:conversationId/members"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/conversations/:conversationId/members"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/conversations/:conversationId/members")

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/v3/conversations/:conversationId/members') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/conversations/:conversationId/members";

    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}}/v3/conversations/:conversationId/members
http GET {{baseUrl}}/v3/conversations/:conversationId/members
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v3/conversations/:conversationId/members
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/conversations/:conversationId/members")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET GetConversationPagedMembers
{{baseUrl}}/v3/conversations/:conversationId/pagedmembers
QUERY PARAMS

conversationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/conversations/:conversationId/pagedmembers");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v3/conversations/:conversationId/pagedmembers")
require "http/client"

url = "{{baseUrl}}/v3/conversations/:conversationId/pagedmembers"

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}}/v3/conversations/:conversationId/pagedmembers"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3/conversations/:conversationId/pagedmembers");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/conversations/:conversationId/pagedmembers"

	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/v3/conversations/:conversationId/pagedmembers HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v3/conversations/:conversationId/pagedmembers")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/conversations/:conversationId/pagedmembers"))
    .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}}/v3/conversations/:conversationId/pagedmembers")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v3/conversations/:conversationId/pagedmembers")
  .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}}/v3/conversations/:conversationId/pagedmembers');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v3/conversations/:conversationId/pagedmembers'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/conversations/:conversationId/pagedmembers';
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}}/v3/conversations/:conversationId/pagedmembers',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v3/conversations/:conversationId/pagedmembers")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/conversations/:conversationId/pagedmembers',
  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}}/v3/conversations/:conversationId/pagedmembers'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v3/conversations/:conversationId/pagedmembers');

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}}/v3/conversations/:conversationId/pagedmembers'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/conversations/:conversationId/pagedmembers';
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}}/v3/conversations/:conversationId/pagedmembers"]
                                                       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}}/v3/conversations/:conversationId/pagedmembers" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/conversations/:conversationId/pagedmembers",
  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}}/v3/conversations/:conversationId/pagedmembers');

echo $response->getBody();
setUrl('{{baseUrl}}/v3/conversations/:conversationId/pagedmembers');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v3/conversations/:conversationId/pagedmembers');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/conversations/:conversationId/pagedmembers' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/conversations/:conversationId/pagedmembers' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v3/conversations/:conversationId/pagedmembers")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/conversations/:conversationId/pagedmembers"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/conversations/:conversationId/pagedmembers"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/conversations/:conversationId/pagedmembers")

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/v3/conversations/:conversationId/pagedmembers') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/conversations/:conversationId/pagedmembers";

    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}}/v3/conversations/:conversationId/pagedmembers
http GET {{baseUrl}}/v3/conversations/:conversationId/pagedmembers
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v3/conversations/:conversationId/pagedmembers
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/conversations/:conversationId/pagedmembers")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET GetConversations
{{baseUrl}}/v3/conversations
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/conversations");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v3/conversations")
require "http/client"

url = "{{baseUrl}}/v3/conversations"

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}}/v3/conversations"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3/conversations");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/conversations"

	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/v3/conversations HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v3/conversations")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/conversations"))
    .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}}/v3/conversations")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v3/conversations")
  .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}}/v3/conversations');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/v3/conversations'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/conversations';
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}}/v3/conversations',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v3/conversations")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/conversations',
  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}}/v3/conversations'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v3/conversations');

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}}/v3/conversations'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/conversations';
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}}/v3/conversations"]
                                                       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}}/v3/conversations" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/conversations",
  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}}/v3/conversations');

echo $response->getBody();
setUrl('{{baseUrl}}/v3/conversations');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v3/conversations');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/conversations' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/conversations' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v3/conversations")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/conversations"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/conversations"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/conversations")

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/v3/conversations') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/conversations";

    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}}/v3/conversations
http GET {{baseUrl}}/v3/conversations
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v3/conversations
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/conversations")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST ReplyToActivity
{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId
QUERY PARAMS

conversationId
activityId
BODY json

{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId");

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  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId" {:content-type :json
                                                                                                    :form-params {:type ""
                                                                                                                  :id ""
                                                                                                                  :timestamp ""
                                                                                                                  :localTimestamp ""
                                                                                                                  :localTimezone ""
                                                                                                                  :callerId ""
                                                                                                                  :serviceUrl ""
                                                                                                                  :channelId ""
                                                                                                                  :from {:id ""
                                                                                                                         :name ""
                                                                                                                         :aadObjectId ""
                                                                                                                         :role ""}
                                                                                                                  :conversation {:isGroup false
                                                                                                                                 :conversationType ""
                                                                                                                                 :tenantId ""
                                                                                                                                 :id ""
                                                                                                                                 :name ""
                                                                                                                                 :aadObjectId ""
                                                                                                                                 :role ""}
                                                                                                                  :recipient {}
                                                                                                                  :textFormat ""
                                                                                                                  :attachmentLayout ""
                                                                                                                  :membersAdded [{}]
                                                                                                                  :membersRemoved [{}]
                                                                                                                  :reactionsAdded [{:type ""}]
                                                                                                                  :reactionsRemoved [{}]
                                                                                                                  :topicName ""
                                                                                                                  :historyDisclosed false
                                                                                                                  :locale ""
                                                                                                                  :text ""
                                                                                                                  :speak ""
                                                                                                                  :inputHint ""
                                                                                                                  :summary ""
                                                                                                                  :suggestedActions {:to []
                                                                                                                                     :actions [{:type ""
                                                                                                                                                :title ""
                                                                                                                                                :image ""
                                                                                                                                                :imageAltText ""
                                                                                                                                                :text ""
                                                                                                                                                :displayText ""
                                                                                                                                                :value {}
                                                                                                                                                :channelData {}}]}
                                                                                                                  :attachments [{:contentType ""
                                                                                                                                 :contentUrl ""
                                                                                                                                 :content {}
                                                                                                                                 :name ""
                                                                                                                                 :thumbnailUrl ""}]
                                                                                                                  :entities [{:type ""}]
                                                                                                                  :channelData {}
                                                                                                                  :action ""
                                                                                                                  :replyToId ""
                                                                                                                  :label ""
                                                                                                                  :valueType ""
                                                                                                                  :value {}
                                                                                                                  :name ""
                                                                                                                  :relatesTo {:activityId ""
                                                                                                                              :user {}
                                                                                                                              :bot {}
                                                                                                                              :conversation {}
                                                                                                                              :channelId ""
                                                                                                                              :serviceUrl ""
                                                                                                                              :locale ""}
                                                                                                                  :code ""
                                                                                                                  :expiration ""
                                                                                                                  :importance ""
                                                                                                                  :deliveryMode ""
                                                                                                                  :listenFor []
                                                                                                                  :textHighlights [{:text ""
                                                                                                                                    :occurrence 0}]
                                                                                                                  :semanticAction {:state ""
                                                                                                                                   :id ""
                                                                                                                                   :entities {}}}})
require "http/client"

url = "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"),
    Content = new StringContent("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"

	payload := strings.NewReader("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/conversations/:conversationId/activities/:activityId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1745

{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId")
  .header("content-type", "application/json")
  .body("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")
  .asString();
const data = JSON.stringify({
  type: '',
  id: '',
  timestamp: '',
  localTimestamp: '',
  localTimezone: '',
  callerId: '',
  serviceUrl: '',
  channelId: '',
  from: {
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  conversation: {
    isGroup: false,
    conversationType: '',
    tenantId: '',
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  recipient: {},
  textFormat: '',
  attachmentLayout: '',
  membersAdded: [
    {}
  ],
  membersRemoved: [
    {}
  ],
  reactionsAdded: [
    {
      type: ''
    }
  ],
  reactionsRemoved: [
    {}
  ],
  topicName: '',
  historyDisclosed: false,
  locale: '',
  text: '',
  speak: '',
  inputHint: '',
  summary: '',
  suggestedActions: {
    to: [],
    actions: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ]
  },
  attachments: [
    {
      contentType: '',
      contentUrl: '',
      content: {},
      name: '',
      thumbnailUrl: ''
    }
  ],
  entities: [
    {
      type: ''
    }
  ],
  channelData: {},
  action: '',
  replyToId: '',
  label: '',
  valueType: '',
  value: {},
  name: '',
  relatesTo: {
    activityId: '',
    user: {},
    bot: {},
    conversation: {},
    channelId: '',
    serviceUrl: '',
    locale: ''
  },
  code: '',
  expiration: '',
  importance: '',
  deliveryMode: '',
  listenFor: [],
  textHighlights: [
    {
      text: '',
      occurrence: 0
    }
  ],
  semanticAction: {
    state: '',
    id: '',
    entities: {}
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId',
  headers: {'content-type': 'application/json'},
  data: {
    type: '',
    id: '',
    timestamp: '',
    localTimestamp: '',
    localTimezone: '',
    callerId: '',
    serviceUrl: '',
    channelId: '',
    from: {id: '', name: '', aadObjectId: '', role: ''},
    conversation: {
      isGroup: false,
      conversationType: '',
      tenantId: '',
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    recipient: {},
    textFormat: '',
    attachmentLayout: '',
    membersAdded: [{}],
    membersRemoved: [{}],
    reactionsAdded: [{type: ''}],
    reactionsRemoved: [{}],
    topicName: '',
    historyDisclosed: false,
    locale: '',
    text: '',
    speak: '',
    inputHint: '',
    summary: '',
    suggestedActions: {
      to: [],
      actions: [
        {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      ]
    },
    attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
    entities: [{type: ''}],
    channelData: {},
    action: '',
    replyToId: '',
    label: '',
    valueType: '',
    value: {},
    name: '',
    relatesTo: {
      activityId: '',
      user: {},
      bot: {},
      conversation: {},
      channelId: '',
      serviceUrl: '',
      locale: ''
    },
    code: '',
    expiration: '',
    importance: '',
    deliveryMode: '',
    listenFor: [],
    textHighlights: [{text: '', occurrence: 0}],
    semanticAction: {state: '', id: '', entities: {}}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"type":"","id":"","timestamp":"","localTimestamp":"","localTimezone":"","callerId":"","serviceUrl":"","channelId":"","from":{"id":"","name":"","aadObjectId":"","role":""},"conversation":{"isGroup":false,"conversationType":"","tenantId":"","id":"","name":"","aadObjectId":"","role":""},"recipient":{},"textFormat":"","attachmentLayout":"","membersAdded":[{}],"membersRemoved":[{}],"reactionsAdded":[{"type":""}],"reactionsRemoved":[{}],"topicName":"","historyDisclosed":false,"locale":"","text":"","speak":"","inputHint":"","summary":"","suggestedActions":{"to":[],"actions":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}]},"attachments":[{"contentType":"","contentUrl":"","content":{},"name":"","thumbnailUrl":""}],"entities":[{"type":""}],"channelData":{},"action":"","replyToId":"","label":"","valueType":"","value":{},"name":"","relatesTo":{"activityId":"","user":{},"bot":{},"conversation":{},"channelId":"","serviceUrl":"","locale":""},"code":"","expiration":"","importance":"","deliveryMode":"","listenFor":[],"textHighlights":[{"text":"","occurrence":0}],"semanticAction":{"state":"","id":"","entities":{}}}'
};

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}}/v3/conversations/:conversationId/activities/:activityId',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "type": "",\n  "id": "",\n  "timestamp": "",\n  "localTimestamp": "",\n  "localTimezone": "",\n  "callerId": "",\n  "serviceUrl": "",\n  "channelId": "",\n  "from": {\n    "id": "",\n    "name": "",\n    "aadObjectId": "",\n    "role": ""\n  },\n  "conversation": {\n    "isGroup": false,\n    "conversationType": "",\n    "tenantId": "",\n    "id": "",\n    "name": "",\n    "aadObjectId": "",\n    "role": ""\n  },\n  "recipient": {},\n  "textFormat": "",\n  "attachmentLayout": "",\n  "membersAdded": [\n    {}\n  ],\n  "membersRemoved": [\n    {}\n  ],\n  "reactionsAdded": [\n    {\n      "type": ""\n    }\n  ],\n  "reactionsRemoved": [\n    {}\n  ],\n  "topicName": "",\n  "historyDisclosed": false,\n  "locale": "",\n  "text": "",\n  "speak": "",\n  "inputHint": "",\n  "summary": "",\n  "suggestedActions": {\n    "to": [],\n    "actions": [\n      {\n        "type": "",\n        "title": "",\n        "image": "",\n        "imageAltText": "",\n        "text": "",\n        "displayText": "",\n        "value": {},\n        "channelData": {}\n      }\n    ]\n  },\n  "attachments": [\n    {\n      "contentType": "",\n      "contentUrl": "",\n      "content": {},\n      "name": "",\n      "thumbnailUrl": ""\n    }\n  ],\n  "entities": [\n    {\n      "type": ""\n    }\n  ],\n  "channelData": {},\n  "action": "",\n  "replyToId": "",\n  "label": "",\n  "valueType": "",\n  "value": {},\n  "name": "",\n  "relatesTo": {\n    "activityId": "",\n    "user": {},\n    "bot": {},\n    "conversation": {},\n    "channelId": "",\n    "serviceUrl": "",\n    "locale": ""\n  },\n  "code": "",\n  "expiration": "",\n  "importance": "",\n  "deliveryMode": "",\n  "listenFor": [],\n  "textHighlights": [\n    {\n      "text": "",\n      "occurrence": 0\n    }\n  ],\n  "semanticAction": {\n    "state": "",\n    "id": "",\n    "entities": {}\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/conversations/:conversationId/activities/:activityId',
  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({
  type: '',
  id: '',
  timestamp: '',
  localTimestamp: '',
  localTimezone: '',
  callerId: '',
  serviceUrl: '',
  channelId: '',
  from: {id: '', name: '', aadObjectId: '', role: ''},
  conversation: {
    isGroup: false,
    conversationType: '',
    tenantId: '',
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  recipient: {},
  textFormat: '',
  attachmentLayout: '',
  membersAdded: [{}],
  membersRemoved: [{}],
  reactionsAdded: [{type: ''}],
  reactionsRemoved: [{}],
  topicName: '',
  historyDisclosed: false,
  locale: '',
  text: '',
  speak: '',
  inputHint: '',
  summary: '',
  suggestedActions: {
    to: [],
    actions: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ]
  },
  attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
  entities: [{type: ''}],
  channelData: {},
  action: '',
  replyToId: '',
  label: '',
  valueType: '',
  value: {},
  name: '',
  relatesTo: {
    activityId: '',
    user: {},
    bot: {},
    conversation: {},
    channelId: '',
    serviceUrl: '',
    locale: ''
  },
  code: '',
  expiration: '',
  importance: '',
  deliveryMode: '',
  listenFor: [],
  textHighlights: [{text: '', occurrence: 0}],
  semanticAction: {state: '', id: '', entities: {}}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId',
  headers: {'content-type': 'application/json'},
  body: {
    type: '',
    id: '',
    timestamp: '',
    localTimestamp: '',
    localTimezone: '',
    callerId: '',
    serviceUrl: '',
    channelId: '',
    from: {id: '', name: '', aadObjectId: '', role: ''},
    conversation: {
      isGroup: false,
      conversationType: '',
      tenantId: '',
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    recipient: {},
    textFormat: '',
    attachmentLayout: '',
    membersAdded: [{}],
    membersRemoved: [{}],
    reactionsAdded: [{type: ''}],
    reactionsRemoved: [{}],
    topicName: '',
    historyDisclosed: false,
    locale: '',
    text: '',
    speak: '',
    inputHint: '',
    summary: '',
    suggestedActions: {
      to: [],
      actions: [
        {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      ]
    },
    attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
    entities: [{type: ''}],
    channelData: {},
    action: '',
    replyToId: '',
    label: '',
    valueType: '',
    value: {},
    name: '',
    relatesTo: {
      activityId: '',
      user: {},
      bot: {},
      conversation: {},
      channelId: '',
      serviceUrl: '',
      locale: ''
    },
    code: '',
    expiration: '',
    importance: '',
    deliveryMode: '',
    listenFor: [],
    textHighlights: [{text: '', occurrence: 0}],
    semanticAction: {state: '', id: '', entities: {}}
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  type: '',
  id: '',
  timestamp: '',
  localTimestamp: '',
  localTimezone: '',
  callerId: '',
  serviceUrl: '',
  channelId: '',
  from: {
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  conversation: {
    isGroup: false,
    conversationType: '',
    tenantId: '',
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  recipient: {},
  textFormat: '',
  attachmentLayout: '',
  membersAdded: [
    {}
  ],
  membersRemoved: [
    {}
  ],
  reactionsAdded: [
    {
      type: ''
    }
  ],
  reactionsRemoved: [
    {}
  ],
  topicName: '',
  historyDisclosed: false,
  locale: '',
  text: '',
  speak: '',
  inputHint: '',
  summary: '',
  suggestedActions: {
    to: [],
    actions: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ]
  },
  attachments: [
    {
      contentType: '',
      contentUrl: '',
      content: {},
      name: '',
      thumbnailUrl: ''
    }
  ],
  entities: [
    {
      type: ''
    }
  ],
  channelData: {},
  action: '',
  replyToId: '',
  label: '',
  valueType: '',
  value: {},
  name: '',
  relatesTo: {
    activityId: '',
    user: {},
    bot: {},
    conversation: {},
    channelId: '',
    serviceUrl: '',
    locale: ''
  },
  code: '',
  expiration: '',
  importance: '',
  deliveryMode: '',
  listenFor: [],
  textHighlights: [
    {
      text: '',
      occurrence: 0
    }
  ],
  semanticAction: {
    state: '',
    id: '',
    entities: {}
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId',
  headers: {'content-type': 'application/json'},
  data: {
    type: '',
    id: '',
    timestamp: '',
    localTimestamp: '',
    localTimezone: '',
    callerId: '',
    serviceUrl: '',
    channelId: '',
    from: {id: '', name: '', aadObjectId: '', role: ''},
    conversation: {
      isGroup: false,
      conversationType: '',
      tenantId: '',
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    recipient: {},
    textFormat: '',
    attachmentLayout: '',
    membersAdded: [{}],
    membersRemoved: [{}],
    reactionsAdded: [{type: ''}],
    reactionsRemoved: [{}],
    topicName: '',
    historyDisclosed: false,
    locale: '',
    text: '',
    speak: '',
    inputHint: '',
    summary: '',
    suggestedActions: {
      to: [],
      actions: [
        {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      ]
    },
    attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
    entities: [{type: ''}],
    channelData: {},
    action: '',
    replyToId: '',
    label: '',
    valueType: '',
    value: {},
    name: '',
    relatesTo: {
      activityId: '',
      user: {},
      bot: {},
      conversation: {},
      channelId: '',
      serviceUrl: '',
      locale: ''
    },
    code: '',
    expiration: '',
    importance: '',
    deliveryMode: '',
    listenFor: [],
    textHighlights: [{text: '', occurrence: 0}],
    semanticAction: {state: '', id: '', entities: {}}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"type":"","id":"","timestamp":"","localTimestamp":"","localTimezone":"","callerId":"","serviceUrl":"","channelId":"","from":{"id":"","name":"","aadObjectId":"","role":""},"conversation":{"isGroup":false,"conversationType":"","tenantId":"","id":"","name":"","aadObjectId":"","role":""},"recipient":{},"textFormat":"","attachmentLayout":"","membersAdded":[{}],"membersRemoved":[{}],"reactionsAdded":[{"type":""}],"reactionsRemoved":[{}],"topicName":"","historyDisclosed":false,"locale":"","text":"","speak":"","inputHint":"","summary":"","suggestedActions":{"to":[],"actions":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}]},"attachments":[{"contentType":"","contentUrl":"","content":{},"name":"","thumbnailUrl":""}],"entities":[{"type":""}],"channelData":{},"action":"","replyToId":"","label":"","valueType":"","value":{},"name":"","relatesTo":{"activityId":"","user":{},"bot":{},"conversation":{},"channelId":"","serviceUrl":"","locale":""},"code":"","expiration":"","importance":"","deliveryMode":"","listenFor":[],"textHighlights":[{"text":"","occurrence":0}],"semanticAction":{"state":"","id":"","entities":{}}}'
};

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 = @{ @"type": @"",
                              @"id": @"",
                              @"timestamp": @"",
                              @"localTimestamp": @"",
                              @"localTimezone": @"",
                              @"callerId": @"",
                              @"serviceUrl": @"",
                              @"channelId": @"",
                              @"from": @{ @"id": @"", @"name": @"", @"aadObjectId": @"", @"role": @"" },
                              @"conversation": @{ @"isGroup": @NO, @"conversationType": @"", @"tenantId": @"", @"id": @"", @"name": @"", @"aadObjectId": @"", @"role": @"" },
                              @"recipient": @{  },
                              @"textFormat": @"",
                              @"attachmentLayout": @"",
                              @"membersAdded": @[ @{  } ],
                              @"membersRemoved": @[ @{  } ],
                              @"reactionsAdded": @[ @{ @"type": @"" } ],
                              @"reactionsRemoved": @[ @{  } ],
                              @"topicName": @"",
                              @"historyDisclosed": @NO,
                              @"locale": @"",
                              @"text": @"",
                              @"speak": @"",
                              @"inputHint": @"",
                              @"summary": @"",
                              @"suggestedActions": @{ @"to": @[  ], @"actions": @[ @{ @"type": @"", @"title": @"", @"image": @"", @"imageAltText": @"", @"text": @"", @"displayText": @"", @"value": @{  }, @"channelData": @{  } } ] },
                              @"attachments": @[ @{ @"contentType": @"", @"contentUrl": @"", @"content": @{  }, @"name": @"", @"thumbnailUrl": @"" } ],
                              @"entities": @[ @{ @"type": @"" } ],
                              @"channelData": @{  },
                              @"action": @"",
                              @"replyToId": @"",
                              @"label": @"",
                              @"valueType": @"",
                              @"value": @{  },
                              @"name": @"",
                              @"relatesTo": @{ @"activityId": @"", @"user": @{  }, @"bot": @{  }, @"conversation": @{  }, @"channelId": @"", @"serviceUrl": @"", @"locale": @"" },
                              @"code": @"",
                              @"expiration": @"",
                              @"importance": @"",
                              @"deliveryMode": @"",
                              @"listenFor": @[  ],
                              @"textHighlights": @[ @{ @"text": @"", @"occurrence": @0 } ],
                              @"semanticAction": @{ @"state": @"", @"id": @"", @"entities": @{  } } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'type' => '',
    'id' => '',
    'timestamp' => '',
    'localTimestamp' => '',
    'localTimezone' => '',
    'callerId' => '',
    'serviceUrl' => '',
    'channelId' => '',
    'from' => [
        'id' => '',
        'name' => '',
        'aadObjectId' => '',
        'role' => ''
    ],
    'conversation' => [
        'isGroup' => null,
        'conversationType' => '',
        'tenantId' => '',
        'id' => '',
        'name' => '',
        'aadObjectId' => '',
        'role' => ''
    ],
    'recipient' => [
        
    ],
    'textFormat' => '',
    'attachmentLayout' => '',
    'membersAdded' => [
        [
                
        ]
    ],
    'membersRemoved' => [
        [
                
        ]
    ],
    'reactionsAdded' => [
        [
                'type' => ''
        ]
    ],
    'reactionsRemoved' => [
        [
                
        ]
    ],
    'topicName' => '',
    'historyDisclosed' => null,
    'locale' => '',
    'text' => '',
    'speak' => '',
    'inputHint' => '',
    'summary' => '',
    'suggestedActions' => [
        'to' => [
                
        ],
        'actions' => [
                [
                                'type' => '',
                                'title' => '',
                                'image' => '',
                                'imageAltText' => '',
                                'text' => '',
                                'displayText' => '',
                                'value' => [
                                                                
                                ],
                                'channelData' => [
                                                                
                                ]
                ]
        ]
    ],
    'attachments' => [
        [
                'contentType' => '',
                'contentUrl' => '',
                'content' => [
                                
                ],
                'name' => '',
                'thumbnailUrl' => ''
        ]
    ],
    'entities' => [
        [
                'type' => ''
        ]
    ],
    'channelData' => [
        
    ],
    'action' => '',
    'replyToId' => '',
    'label' => '',
    'valueType' => '',
    'value' => [
        
    ],
    'name' => '',
    'relatesTo' => [
        'activityId' => '',
        'user' => [
                
        ],
        'bot' => [
                
        ],
        'conversation' => [
                
        ],
        'channelId' => '',
        'serviceUrl' => '',
        'locale' => ''
    ],
    'code' => '',
    'expiration' => '',
    'importance' => '',
    'deliveryMode' => '',
    'listenFor' => [
        
    ],
    'textHighlights' => [
        [
                'text' => '',
                'occurrence' => 0
        ]
    ],
    'semanticAction' => [
        'state' => '',
        'id' => '',
        'entities' => [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId', [
  'body' => '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'type' => '',
  'id' => '',
  'timestamp' => '',
  'localTimestamp' => '',
  'localTimezone' => '',
  'callerId' => '',
  'serviceUrl' => '',
  'channelId' => '',
  'from' => [
    'id' => '',
    'name' => '',
    'aadObjectId' => '',
    'role' => ''
  ],
  'conversation' => [
    'isGroup' => null,
    'conversationType' => '',
    'tenantId' => '',
    'id' => '',
    'name' => '',
    'aadObjectId' => '',
    'role' => ''
  ],
  'recipient' => [
    
  ],
  'textFormat' => '',
  'attachmentLayout' => '',
  'membersAdded' => [
    [
        
    ]
  ],
  'membersRemoved' => [
    [
        
    ]
  ],
  'reactionsAdded' => [
    [
        'type' => ''
    ]
  ],
  'reactionsRemoved' => [
    [
        
    ]
  ],
  'topicName' => '',
  'historyDisclosed' => null,
  'locale' => '',
  'text' => '',
  'speak' => '',
  'inputHint' => '',
  'summary' => '',
  'suggestedActions' => [
    'to' => [
        
    ],
    'actions' => [
        [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ]
  ],
  'attachments' => [
    [
        'contentType' => '',
        'contentUrl' => '',
        'content' => [
                
        ],
        'name' => '',
        'thumbnailUrl' => ''
    ]
  ],
  'entities' => [
    [
        'type' => ''
    ]
  ],
  'channelData' => [
    
  ],
  'action' => '',
  'replyToId' => '',
  'label' => '',
  'valueType' => '',
  'value' => [
    
  ],
  'name' => '',
  'relatesTo' => [
    'activityId' => '',
    'user' => [
        
    ],
    'bot' => [
        
    ],
    'conversation' => [
        
    ],
    'channelId' => '',
    'serviceUrl' => '',
    'locale' => ''
  ],
  'code' => '',
  'expiration' => '',
  'importance' => '',
  'deliveryMode' => '',
  'listenFor' => [
    
  ],
  'textHighlights' => [
    [
        'text' => '',
        'occurrence' => 0
    ]
  ],
  'semanticAction' => [
    'state' => '',
    'id' => '',
    'entities' => [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'type' => '',
  'id' => '',
  'timestamp' => '',
  'localTimestamp' => '',
  'localTimezone' => '',
  'callerId' => '',
  'serviceUrl' => '',
  'channelId' => '',
  'from' => [
    'id' => '',
    'name' => '',
    'aadObjectId' => '',
    'role' => ''
  ],
  'conversation' => [
    'isGroup' => null,
    'conversationType' => '',
    'tenantId' => '',
    'id' => '',
    'name' => '',
    'aadObjectId' => '',
    'role' => ''
  ],
  'recipient' => [
    
  ],
  'textFormat' => '',
  'attachmentLayout' => '',
  'membersAdded' => [
    [
        
    ]
  ],
  'membersRemoved' => [
    [
        
    ]
  ],
  'reactionsAdded' => [
    [
        'type' => ''
    ]
  ],
  'reactionsRemoved' => [
    [
        
    ]
  ],
  'topicName' => '',
  'historyDisclosed' => null,
  'locale' => '',
  'text' => '',
  'speak' => '',
  'inputHint' => '',
  'summary' => '',
  'suggestedActions' => [
    'to' => [
        
    ],
    'actions' => [
        [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ]
  ],
  'attachments' => [
    [
        'contentType' => '',
        'contentUrl' => '',
        'content' => [
                
        ],
        'name' => '',
        'thumbnailUrl' => ''
    ]
  ],
  'entities' => [
    [
        'type' => ''
    ]
  ],
  'channelData' => [
    
  ],
  'action' => '',
  'replyToId' => '',
  'label' => '',
  'valueType' => '',
  'value' => [
    
  ],
  'name' => '',
  'relatesTo' => [
    'activityId' => '',
    'user' => [
        
    ],
    'bot' => [
        
    ],
    'conversation' => [
        
    ],
    'channelId' => '',
    'serviceUrl' => '',
    'locale' => ''
  ],
  'code' => '',
  'expiration' => '',
  'importance' => '',
  'deliveryMode' => '',
  'listenFor' => [
    
  ],
  'textHighlights' => [
    [
        'text' => '',
        'occurrence' => 0
    ]
  ],
  'semanticAction' => [
    'state' => '',
    'id' => '',
    'entities' => [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/conversations/:conversationId/activities/:activityId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"

payload = {
    "type": "",
    "id": "",
    "timestamp": "",
    "localTimestamp": "",
    "localTimezone": "",
    "callerId": "",
    "serviceUrl": "",
    "channelId": "",
    "from": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
    },
    "conversation": {
        "isGroup": False,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
    },
    "recipient": {},
    "textFormat": "",
    "attachmentLayout": "",
    "membersAdded": [{}],
    "membersRemoved": [{}],
    "reactionsAdded": [{ "type": "" }],
    "reactionsRemoved": [{}],
    "topicName": "",
    "historyDisclosed": False,
    "locale": "",
    "text": "",
    "speak": "",
    "inputHint": "",
    "summary": "",
    "suggestedActions": {
        "to": [],
        "actions": [
            {
                "type": "",
                "title": "",
                "image": "",
                "imageAltText": "",
                "text": "",
                "displayText": "",
                "value": {},
                "channelData": {}
            }
        ]
    },
    "attachments": [
        {
            "contentType": "",
            "contentUrl": "",
            "content": {},
            "name": "",
            "thumbnailUrl": ""
        }
    ],
    "entities": [{ "type": "" }],
    "channelData": {},
    "action": "",
    "replyToId": "",
    "label": "",
    "valueType": "",
    "value": {},
    "name": "",
    "relatesTo": {
        "activityId": "",
        "user": {},
        "bot": {},
        "conversation": {},
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
    },
    "code": "",
    "expiration": "",
    "importance": "",
    "deliveryMode": "",
    "listenFor": [],
    "textHighlights": [
        {
            "text": "",
            "occurrence": 0
        }
    ],
    "semanticAction": {
        "state": "",
        "id": "",
        "entities": {}
    }
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"

payload <- "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/conversations/:conversationId/activities/:activityId') do |req|
  req.body = "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId";

    let payload = json!({
        "type": "",
        "id": "",
        "timestamp": "",
        "localTimestamp": "",
        "localTimezone": "",
        "callerId": "",
        "serviceUrl": "",
        "channelId": "",
        "from": json!({
            "id": "",
            "name": "",
            "aadObjectId": "",
            "role": ""
        }),
        "conversation": json!({
            "isGroup": false,
            "conversationType": "",
            "tenantId": "",
            "id": "",
            "name": "",
            "aadObjectId": "",
            "role": ""
        }),
        "recipient": json!({}),
        "textFormat": "",
        "attachmentLayout": "",
        "membersAdded": (json!({})),
        "membersRemoved": (json!({})),
        "reactionsAdded": (json!({"type": ""})),
        "reactionsRemoved": (json!({})),
        "topicName": "",
        "historyDisclosed": false,
        "locale": "",
        "text": "",
        "speak": "",
        "inputHint": "",
        "summary": "",
        "suggestedActions": json!({
            "to": (),
            "actions": (
                json!({
                    "type": "",
                    "title": "",
                    "image": "",
                    "imageAltText": "",
                    "text": "",
                    "displayText": "",
                    "value": json!({}),
                    "channelData": json!({})
                })
            )
        }),
        "attachments": (
            json!({
                "contentType": "",
                "contentUrl": "",
                "content": json!({}),
                "name": "",
                "thumbnailUrl": ""
            })
        ),
        "entities": (json!({"type": ""})),
        "channelData": json!({}),
        "action": "",
        "replyToId": "",
        "label": "",
        "valueType": "",
        "value": json!({}),
        "name": "",
        "relatesTo": json!({
            "activityId": "",
            "user": json!({}),
            "bot": json!({}),
            "conversation": json!({}),
            "channelId": "",
            "serviceUrl": "",
            "locale": ""
        }),
        "code": "",
        "expiration": "",
        "importance": "",
        "deliveryMode": "",
        "listenFor": (),
        "textHighlights": (
            json!({
                "text": "",
                "occurrence": 0
            })
        ),
        "semanticAction": json!({
            "state": "",
            "id": "",
            "entities": json!({})
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/conversations/:conversationId/activities/:activityId \
  --header 'content-type: application/json' \
  --data '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}'
echo '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}' |  \
  http POST {{baseUrl}}/v3/conversations/:conversationId/activities/:activityId \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "type": "",\n  "id": "",\n  "timestamp": "",\n  "localTimestamp": "",\n  "localTimezone": "",\n  "callerId": "",\n  "serviceUrl": "",\n  "channelId": "",\n  "from": {\n    "id": "",\n    "name": "",\n    "aadObjectId": "",\n    "role": ""\n  },\n  "conversation": {\n    "isGroup": false,\n    "conversationType": "",\n    "tenantId": "",\n    "id": "",\n    "name": "",\n    "aadObjectId": "",\n    "role": ""\n  },\n  "recipient": {},\n  "textFormat": "",\n  "attachmentLayout": "",\n  "membersAdded": [\n    {}\n  ],\n  "membersRemoved": [\n    {}\n  ],\n  "reactionsAdded": [\n    {\n      "type": ""\n    }\n  ],\n  "reactionsRemoved": [\n    {}\n  ],\n  "topicName": "",\n  "historyDisclosed": false,\n  "locale": "",\n  "text": "",\n  "speak": "",\n  "inputHint": "",\n  "summary": "",\n  "suggestedActions": {\n    "to": [],\n    "actions": [\n      {\n        "type": "",\n        "title": "",\n        "image": "",\n        "imageAltText": "",\n        "text": "",\n        "displayText": "",\n        "value": {},\n        "channelData": {}\n      }\n    ]\n  },\n  "attachments": [\n    {\n      "contentType": "",\n      "contentUrl": "",\n      "content": {},\n      "name": "",\n      "thumbnailUrl": ""\n    }\n  ],\n  "entities": [\n    {\n      "type": ""\n    }\n  ],\n  "channelData": {},\n  "action": "",\n  "replyToId": "",\n  "label": "",\n  "valueType": "",\n  "value": {},\n  "name": "",\n  "relatesTo": {\n    "activityId": "",\n    "user": {},\n    "bot": {},\n    "conversation": {},\n    "channelId": "",\n    "serviceUrl": "",\n    "locale": ""\n  },\n  "code": "",\n  "expiration": "",\n  "importance": "",\n  "deliveryMode": "",\n  "listenFor": [],\n  "textHighlights": [\n    {\n      "text": "",\n      "occurrence": 0\n    }\n  ],\n  "semanticAction": {\n    "state": "",\n    "id": "",\n    "entities": {}\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v3/conversations/:conversationId/activities/:activityId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": [
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  ],
  "conversation": [
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  ],
  "recipient": [],
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [[]],
  "membersRemoved": [[]],
  "reactionsAdded": [["type": ""]],
  "reactionsRemoved": [[]],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": [
    "to": [],
    "actions": [
      [
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": [],
        "channelData": []
      ]
    ]
  ],
  "attachments": [
    [
      "contentType": "",
      "contentUrl": "",
      "content": [],
      "name": "",
      "thumbnailUrl": ""
    ]
  ],
  "entities": [["type": ""]],
  "channelData": [],
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": [],
  "name": "",
  "relatesTo": [
    "activityId": "",
    "user": [],
    "bot": [],
    "conversation": [],
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  ],
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    [
      "text": "",
      "occurrence": 0
    ]
  ],
  "semanticAction": [
    "state": "",
    "id": "",
    "entities": []
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST SendConversationHistory
{{baseUrl}}/v3/conversations/:conversationId/activities/history
QUERY PARAMS

conversationId
BODY json

{
  "activities": [
    {
      "type": "",
      "id": "",
      "timestamp": "",
      "localTimestamp": "",
      "localTimezone": "",
      "callerId": "",
      "serviceUrl": "",
      "channelId": "",
      "from": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "conversation": {
        "isGroup": false,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "recipient": {},
      "textFormat": "",
      "attachmentLayout": "",
      "membersAdded": [
        {}
      ],
      "membersRemoved": [
        {}
      ],
      "reactionsAdded": [
        {
          "type": ""
        }
      ],
      "reactionsRemoved": [
        {}
      ],
      "topicName": "",
      "historyDisclosed": false,
      "locale": "",
      "text": "",
      "speak": "",
      "inputHint": "",
      "summary": "",
      "suggestedActions": {
        "to": [],
        "actions": [
          {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
          }
        ]
      },
      "attachments": [
        {
          "contentType": "",
          "contentUrl": "",
          "content": {},
          "name": "",
          "thumbnailUrl": ""
        }
      ],
      "entities": [
        {
          "type": ""
        }
      ],
      "channelData": {},
      "action": "",
      "replyToId": "",
      "label": "",
      "valueType": "",
      "value": {},
      "name": "",
      "relatesTo": {
        "activityId": "",
        "user": {},
        "bot": {},
        "conversation": {},
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
      },
      "code": "",
      "expiration": "",
      "importance": "",
      "deliveryMode": "",
      "listenFor": [],
      "textHighlights": [
        {
          "text": "",
          "occurrence": 0
        }
      ],
      "semanticAction": {
        "state": "",
        "id": "",
        "entities": {}
      }
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/conversations/:conversationId/activities/history");

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  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/conversations/:conversationId/activities/history" {:content-type :json
                                                                                                :form-params {:activities [{:type ""
                                                                                                                            :id ""
                                                                                                                            :timestamp ""
                                                                                                                            :localTimestamp ""
                                                                                                                            :localTimezone ""
                                                                                                                            :callerId ""
                                                                                                                            :serviceUrl ""
                                                                                                                            :channelId ""
                                                                                                                            :from {:id ""
                                                                                                                                   :name ""
                                                                                                                                   :aadObjectId ""
                                                                                                                                   :role ""}
                                                                                                                            :conversation {:isGroup false
                                                                                                                                           :conversationType ""
                                                                                                                                           :tenantId ""
                                                                                                                                           :id ""
                                                                                                                                           :name ""
                                                                                                                                           :aadObjectId ""
                                                                                                                                           :role ""}
                                                                                                                            :recipient {}
                                                                                                                            :textFormat ""
                                                                                                                            :attachmentLayout ""
                                                                                                                            :membersAdded [{}]
                                                                                                                            :membersRemoved [{}]
                                                                                                                            :reactionsAdded [{:type ""}]
                                                                                                                            :reactionsRemoved [{}]
                                                                                                                            :topicName ""
                                                                                                                            :historyDisclosed false
                                                                                                                            :locale ""
                                                                                                                            :text ""
                                                                                                                            :speak ""
                                                                                                                            :inputHint ""
                                                                                                                            :summary ""
                                                                                                                            :suggestedActions {:to []
                                                                                                                                               :actions [{:type ""
                                                                                                                                                          :title ""
                                                                                                                                                          :image ""
                                                                                                                                                          :imageAltText ""
                                                                                                                                                          :text ""
                                                                                                                                                          :displayText ""
                                                                                                                                                          :value {}
                                                                                                                                                          :channelData {}}]}
                                                                                                                            :attachments [{:contentType ""
                                                                                                                                           :contentUrl ""
                                                                                                                                           :content {}
                                                                                                                                           :name ""
                                                                                                                                           :thumbnailUrl ""}]
                                                                                                                            :entities [{:type ""}]
                                                                                                                            :channelData {}
                                                                                                                            :action ""
                                                                                                                            :replyToId ""
                                                                                                                            :label ""
                                                                                                                            :valueType ""
                                                                                                                            :value {}
                                                                                                                            :name ""
                                                                                                                            :relatesTo {:activityId ""
                                                                                                                                        :user {}
                                                                                                                                        :bot {}
                                                                                                                                        :conversation {}
                                                                                                                                        :channelId ""
                                                                                                                                        :serviceUrl ""
                                                                                                                                        :locale ""}
                                                                                                                            :code ""
                                                                                                                            :expiration ""
                                                                                                                            :importance ""
                                                                                                                            :deliveryMode ""
                                                                                                                            :listenFor []
                                                                                                                            :textHighlights [{:text ""
                                                                                                                                              :occurrence 0}]
                                                                                                                            :semanticAction {:state ""
                                                                                                                                             :id ""
                                                                                                                                             :entities {}}}]}})
require "http/client"

url = "{{baseUrl}}/v3/conversations/:conversationId/activities/history"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/conversations/:conversationId/activities/history"),
    Content = new StringContent("{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3/conversations/:conversationId/activities/history");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/conversations/:conversationId/activities/history"

	payload := strings.NewReader("{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/conversations/:conversationId/activities/history HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2211

{
  "activities": [
    {
      "type": "",
      "id": "",
      "timestamp": "",
      "localTimestamp": "",
      "localTimezone": "",
      "callerId": "",
      "serviceUrl": "",
      "channelId": "",
      "from": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "conversation": {
        "isGroup": false,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "recipient": {},
      "textFormat": "",
      "attachmentLayout": "",
      "membersAdded": [
        {}
      ],
      "membersRemoved": [
        {}
      ],
      "reactionsAdded": [
        {
          "type": ""
        }
      ],
      "reactionsRemoved": [
        {}
      ],
      "topicName": "",
      "historyDisclosed": false,
      "locale": "",
      "text": "",
      "speak": "",
      "inputHint": "",
      "summary": "",
      "suggestedActions": {
        "to": [],
        "actions": [
          {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
          }
        ]
      },
      "attachments": [
        {
          "contentType": "",
          "contentUrl": "",
          "content": {},
          "name": "",
          "thumbnailUrl": ""
        }
      ],
      "entities": [
        {
          "type": ""
        }
      ],
      "channelData": {},
      "action": "",
      "replyToId": "",
      "label": "",
      "valueType": "",
      "value": {},
      "name": "",
      "relatesTo": {
        "activityId": "",
        "user": {},
        "bot": {},
        "conversation": {},
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
      },
      "code": "",
      "expiration": "",
      "importance": "",
      "deliveryMode": "",
      "listenFor": [],
      "textHighlights": [
        {
          "text": "",
          "occurrence": 0
        }
      ],
      "semanticAction": {
        "state": "",
        "id": "",
        "entities": {}
      }
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/conversations/:conversationId/activities/history")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/conversations/:conversationId/activities/history"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/conversations/:conversationId/activities/history")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/conversations/:conversationId/activities/history")
  .header("content-type", "application/json")
  .body("{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  activities: [
    {
      type: '',
      id: '',
      timestamp: '',
      localTimestamp: '',
      localTimezone: '',
      callerId: '',
      serviceUrl: '',
      channelId: '',
      from: {
        id: '',
        name: '',
        aadObjectId: '',
        role: ''
      },
      conversation: {
        isGroup: false,
        conversationType: '',
        tenantId: '',
        id: '',
        name: '',
        aadObjectId: '',
        role: ''
      },
      recipient: {},
      textFormat: '',
      attachmentLayout: '',
      membersAdded: [
        {}
      ],
      membersRemoved: [
        {}
      ],
      reactionsAdded: [
        {
          type: ''
        }
      ],
      reactionsRemoved: [
        {}
      ],
      topicName: '',
      historyDisclosed: false,
      locale: '',
      text: '',
      speak: '',
      inputHint: '',
      summary: '',
      suggestedActions: {
        to: [],
        actions: [
          {
            type: '',
            title: '',
            image: '',
            imageAltText: '',
            text: '',
            displayText: '',
            value: {},
            channelData: {}
          }
        ]
      },
      attachments: [
        {
          contentType: '',
          contentUrl: '',
          content: {},
          name: '',
          thumbnailUrl: ''
        }
      ],
      entities: [
        {
          type: ''
        }
      ],
      channelData: {},
      action: '',
      replyToId: '',
      label: '',
      valueType: '',
      value: {},
      name: '',
      relatesTo: {
        activityId: '',
        user: {},
        bot: {},
        conversation: {},
        channelId: '',
        serviceUrl: '',
        locale: ''
      },
      code: '',
      expiration: '',
      importance: '',
      deliveryMode: '',
      listenFor: [],
      textHighlights: [
        {
          text: '',
          occurrence: 0
        }
      ],
      semanticAction: {
        state: '',
        id: '',
        entities: {}
      }
    }
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/conversations/:conversationId/activities/history');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/conversations/:conversationId/activities/history',
  headers: {'content-type': 'application/json'},
  data: {
    activities: [
      {
        type: '',
        id: '',
        timestamp: '',
        localTimestamp: '',
        localTimezone: '',
        callerId: '',
        serviceUrl: '',
        channelId: '',
        from: {id: '', name: '', aadObjectId: '', role: ''},
        conversation: {
          isGroup: false,
          conversationType: '',
          tenantId: '',
          id: '',
          name: '',
          aadObjectId: '',
          role: ''
        },
        recipient: {},
        textFormat: '',
        attachmentLayout: '',
        membersAdded: [{}],
        membersRemoved: [{}],
        reactionsAdded: [{type: ''}],
        reactionsRemoved: [{}],
        topicName: '',
        historyDisclosed: false,
        locale: '',
        text: '',
        speak: '',
        inputHint: '',
        summary: '',
        suggestedActions: {
          to: [],
          actions: [
            {
              type: '',
              title: '',
              image: '',
              imageAltText: '',
              text: '',
              displayText: '',
              value: {},
              channelData: {}
            }
          ]
        },
        attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
        entities: [{type: ''}],
        channelData: {},
        action: '',
        replyToId: '',
        label: '',
        valueType: '',
        value: {},
        name: '',
        relatesTo: {
          activityId: '',
          user: {},
          bot: {},
          conversation: {},
          channelId: '',
          serviceUrl: '',
          locale: ''
        },
        code: '',
        expiration: '',
        importance: '',
        deliveryMode: '',
        listenFor: [],
        textHighlights: [{text: '', occurrence: 0}],
        semanticAction: {state: '', id: '', entities: {}}
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/conversations/:conversationId/activities/history';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"activities":[{"type":"","id":"","timestamp":"","localTimestamp":"","localTimezone":"","callerId":"","serviceUrl":"","channelId":"","from":{"id":"","name":"","aadObjectId":"","role":""},"conversation":{"isGroup":false,"conversationType":"","tenantId":"","id":"","name":"","aadObjectId":"","role":""},"recipient":{},"textFormat":"","attachmentLayout":"","membersAdded":[{}],"membersRemoved":[{}],"reactionsAdded":[{"type":""}],"reactionsRemoved":[{}],"topicName":"","historyDisclosed":false,"locale":"","text":"","speak":"","inputHint":"","summary":"","suggestedActions":{"to":[],"actions":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}]},"attachments":[{"contentType":"","contentUrl":"","content":{},"name":"","thumbnailUrl":""}],"entities":[{"type":""}],"channelData":{},"action":"","replyToId":"","label":"","valueType":"","value":{},"name":"","relatesTo":{"activityId":"","user":{},"bot":{},"conversation":{},"channelId":"","serviceUrl":"","locale":""},"code":"","expiration":"","importance":"","deliveryMode":"","listenFor":[],"textHighlights":[{"text":"","occurrence":0}],"semanticAction":{"state":"","id":"","entities":{}}}]}'
};

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}}/v3/conversations/:conversationId/activities/history',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "activities": [\n    {\n      "type": "",\n      "id": "",\n      "timestamp": "",\n      "localTimestamp": "",\n      "localTimezone": "",\n      "callerId": "",\n      "serviceUrl": "",\n      "channelId": "",\n      "from": {\n        "id": "",\n        "name": "",\n        "aadObjectId": "",\n        "role": ""\n      },\n      "conversation": {\n        "isGroup": false,\n        "conversationType": "",\n        "tenantId": "",\n        "id": "",\n        "name": "",\n        "aadObjectId": "",\n        "role": ""\n      },\n      "recipient": {},\n      "textFormat": "",\n      "attachmentLayout": "",\n      "membersAdded": [\n        {}\n      ],\n      "membersRemoved": [\n        {}\n      ],\n      "reactionsAdded": [\n        {\n          "type": ""\n        }\n      ],\n      "reactionsRemoved": [\n        {}\n      ],\n      "topicName": "",\n      "historyDisclosed": false,\n      "locale": "",\n      "text": "",\n      "speak": "",\n      "inputHint": "",\n      "summary": "",\n      "suggestedActions": {\n        "to": [],\n        "actions": [\n          {\n            "type": "",\n            "title": "",\n            "image": "",\n            "imageAltText": "",\n            "text": "",\n            "displayText": "",\n            "value": {},\n            "channelData": {}\n          }\n        ]\n      },\n      "attachments": [\n        {\n          "contentType": "",\n          "contentUrl": "",\n          "content": {},\n          "name": "",\n          "thumbnailUrl": ""\n        }\n      ],\n      "entities": [\n        {\n          "type": ""\n        }\n      ],\n      "channelData": {},\n      "action": "",\n      "replyToId": "",\n      "label": "",\n      "valueType": "",\n      "value": {},\n      "name": "",\n      "relatesTo": {\n        "activityId": "",\n        "user": {},\n        "bot": {},\n        "conversation": {},\n        "channelId": "",\n        "serviceUrl": "",\n        "locale": ""\n      },\n      "code": "",\n      "expiration": "",\n      "importance": "",\n      "deliveryMode": "",\n      "listenFor": [],\n      "textHighlights": [\n        {\n          "text": "",\n          "occurrence": 0\n        }\n      ],\n      "semanticAction": {\n        "state": "",\n        "id": "",\n        "entities": {}\n      }\n    }\n  ]\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/conversations/:conversationId/activities/history")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/conversations/:conversationId/activities/history',
  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({
  activities: [
    {
      type: '',
      id: '',
      timestamp: '',
      localTimestamp: '',
      localTimezone: '',
      callerId: '',
      serviceUrl: '',
      channelId: '',
      from: {id: '', name: '', aadObjectId: '', role: ''},
      conversation: {
        isGroup: false,
        conversationType: '',
        tenantId: '',
        id: '',
        name: '',
        aadObjectId: '',
        role: ''
      },
      recipient: {},
      textFormat: '',
      attachmentLayout: '',
      membersAdded: [{}],
      membersRemoved: [{}],
      reactionsAdded: [{type: ''}],
      reactionsRemoved: [{}],
      topicName: '',
      historyDisclosed: false,
      locale: '',
      text: '',
      speak: '',
      inputHint: '',
      summary: '',
      suggestedActions: {
        to: [],
        actions: [
          {
            type: '',
            title: '',
            image: '',
            imageAltText: '',
            text: '',
            displayText: '',
            value: {},
            channelData: {}
          }
        ]
      },
      attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
      entities: [{type: ''}],
      channelData: {},
      action: '',
      replyToId: '',
      label: '',
      valueType: '',
      value: {},
      name: '',
      relatesTo: {
        activityId: '',
        user: {},
        bot: {},
        conversation: {},
        channelId: '',
        serviceUrl: '',
        locale: ''
      },
      code: '',
      expiration: '',
      importance: '',
      deliveryMode: '',
      listenFor: [],
      textHighlights: [{text: '', occurrence: 0}],
      semanticAction: {state: '', id: '', entities: {}}
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/conversations/:conversationId/activities/history',
  headers: {'content-type': 'application/json'},
  body: {
    activities: [
      {
        type: '',
        id: '',
        timestamp: '',
        localTimestamp: '',
        localTimezone: '',
        callerId: '',
        serviceUrl: '',
        channelId: '',
        from: {id: '', name: '', aadObjectId: '', role: ''},
        conversation: {
          isGroup: false,
          conversationType: '',
          tenantId: '',
          id: '',
          name: '',
          aadObjectId: '',
          role: ''
        },
        recipient: {},
        textFormat: '',
        attachmentLayout: '',
        membersAdded: [{}],
        membersRemoved: [{}],
        reactionsAdded: [{type: ''}],
        reactionsRemoved: [{}],
        topicName: '',
        historyDisclosed: false,
        locale: '',
        text: '',
        speak: '',
        inputHint: '',
        summary: '',
        suggestedActions: {
          to: [],
          actions: [
            {
              type: '',
              title: '',
              image: '',
              imageAltText: '',
              text: '',
              displayText: '',
              value: {},
              channelData: {}
            }
          ]
        },
        attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
        entities: [{type: ''}],
        channelData: {},
        action: '',
        replyToId: '',
        label: '',
        valueType: '',
        value: {},
        name: '',
        relatesTo: {
          activityId: '',
          user: {},
          bot: {},
          conversation: {},
          channelId: '',
          serviceUrl: '',
          locale: ''
        },
        code: '',
        expiration: '',
        importance: '',
        deliveryMode: '',
        listenFor: [],
        textHighlights: [{text: '', occurrence: 0}],
        semanticAction: {state: '', id: '', entities: {}}
      }
    ]
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/conversations/:conversationId/activities/history');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  activities: [
    {
      type: '',
      id: '',
      timestamp: '',
      localTimestamp: '',
      localTimezone: '',
      callerId: '',
      serviceUrl: '',
      channelId: '',
      from: {
        id: '',
        name: '',
        aadObjectId: '',
        role: ''
      },
      conversation: {
        isGroup: false,
        conversationType: '',
        tenantId: '',
        id: '',
        name: '',
        aadObjectId: '',
        role: ''
      },
      recipient: {},
      textFormat: '',
      attachmentLayout: '',
      membersAdded: [
        {}
      ],
      membersRemoved: [
        {}
      ],
      reactionsAdded: [
        {
          type: ''
        }
      ],
      reactionsRemoved: [
        {}
      ],
      topicName: '',
      historyDisclosed: false,
      locale: '',
      text: '',
      speak: '',
      inputHint: '',
      summary: '',
      suggestedActions: {
        to: [],
        actions: [
          {
            type: '',
            title: '',
            image: '',
            imageAltText: '',
            text: '',
            displayText: '',
            value: {},
            channelData: {}
          }
        ]
      },
      attachments: [
        {
          contentType: '',
          contentUrl: '',
          content: {},
          name: '',
          thumbnailUrl: ''
        }
      ],
      entities: [
        {
          type: ''
        }
      ],
      channelData: {},
      action: '',
      replyToId: '',
      label: '',
      valueType: '',
      value: {},
      name: '',
      relatesTo: {
        activityId: '',
        user: {},
        bot: {},
        conversation: {},
        channelId: '',
        serviceUrl: '',
        locale: ''
      },
      code: '',
      expiration: '',
      importance: '',
      deliveryMode: '',
      listenFor: [],
      textHighlights: [
        {
          text: '',
          occurrence: 0
        }
      ],
      semanticAction: {
        state: '',
        id: '',
        entities: {}
      }
    }
  ]
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/conversations/:conversationId/activities/history',
  headers: {'content-type': 'application/json'},
  data: {
    activities: [
      {
        type: '',
        id: '',
        timestamp: '',
        localTimestamp: '',
        localTimezone: '',
        callerId: '',
        serviceUrl: '',
        channelId: '',
        from: {id: '', name: '', aadObjectId: '', role: ''},
        conversation: {
          isGroup: false,
          conversationType: '',
          tenantId: '',
          id: '',
          name: '',
          aadObjectId: '',
          role: ''
        },
        recipient: {},
        textFormat: '',
        attachmentLayout: '',
        membersAdded: [{}],
        membersRemoved: [{}],
        reactionsAdded: [{type: ''}],
        reactionsRemoved: [{}],
        topicName: '',
        historyDisclosed: false,
        locale: '',
        text: '',
        speak: '',
        inputHint: '',
        summary: '',
        suggestedActions: {
          to: [],
          actions: [
            {
              type: '',
              title: '',
              image: '',
              imageAltText: '',
              text: '',
              displayText: '',
              value: {},
              channelData: {}
            }
          ]
        },
        attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
        entities: [{type: ''}],
        channelData: {},
        action: '',
        replyToId: '',
        label: '',
        valueType: '',
        value: {},
        name: '',
        relatesTo: {
          activityId: '',
          user: {},
          bot: {},
          conversation: {},
          channelId: '',
          serviceUrl: '',
          locale: ''
        },
        code: '',
        expiration: '',
        importance: '',
        deliveryMode: '',
        listenFor: [],
        textHighlights: [{text: '', occurrence: 0}],
        semanticAction: {state: '', id: '', entities: {}}
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/conversations/:conversationId/activities/history';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"activities":[{"type":"","id":"","timestamp":"","localTimestamp":"","localTimezone":"","callerId":"","serviceUrl":"","channelId":"","from":{"id":"","name":"","aadObjectId":"","role":""},"conversation":{"isGroup":false,"conversationType":"","tenantId":"","id":"","name":"","aadObjectId":"","role":""},"recipient":{},"textFormat":"","attachmentLayout":"","membersAdded":[{}],"membersRemoved":[{}],"reactionsAdded":[{"type":""}],"reactionsRemoved":[{}],"topicName":"","historyDisclosed":false,"locale":"","text":"","speak":"","inputHint":"","summary":"","suggestedActions":{"to":[],"actions":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}]},"attachments":[{"contentType":"","contentUrl":"","content":{},"name":"","thumbnailUrl":""}],"entities":[{"type":""}],"channelData":{},"action":"","replyToId":"","label":"","valueType":"","value":{},"name":"","relatesTo":{"activityId":"","user":{},"bot":{},"conversation":{},"channelId":"","serviceUrl":"","locale":""},"code":"","expiration":"","importance":"","deliveryMode":"","listenFor":[],"textHighlights":[{"text":"","occurrence":0}],"semanticAction":{"state":"","id":"","entities":{}}}]}'
};

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 = @{ @"activities": @[ @{ @"type": @"", @"id": @"", @"timestamp": @"", @"localTimestamp": @"", @"localTimezone": @"", @"callerId": @"", @"serviceUrl": @"", @"channelId": @"", @"from": @{ @"id": @"", @"name": @"", @"aadObjectId": @"", @"role": @"" }, @"conversation": @{ @"isGroup": @NO, @"conversationType": @"", @"tenantId": @"", @"id": @"", @"name": @"", @"aadObjectId": @"", @"role": @"" }, @"recipient": @{  }, @"textFormat": @"", @"attachmentLayout": @"", @"membersAdded": @[ @{  } ], @"membersRemoved": @[ @{  } ], @"reactionsAdded": @[ @{ @"type": @"" } ], @"reactionsRemoved": @[ @{  } ], @"topicName": @"", @"historyDisclosed": @NO, @"locale": @"", @"text": @"", @"speak": @"", @"inputHint": @"", @"summary": @"", @"suggestedActions": @{ @"to": @[  ], @"actions": @[ @{ @"type": @"", @"title": @"", @"image": @"", @"imageAltText": @"", @"text": @"", @"displayText": @"", @"value": @{  }, @"channelData": @{  } } ] }, @"attachments": @[ @{ @"contentType": @"", @"contentUrl": @"", @"content": @{  }, @"name": @"", @"thumbnailUrl": @"" } ], @"entities": @[ @{ @"type": @"" } ], @"channelData": @{  }, @"action": @"", @"replyToId": @"", @"label": @"", @"valueType": @"", @"value": @{  }, @"name": @"", @"relatesTo": @{ @"activityId": @"", @"user": @{  }, @"bot": @{  }, @"conversation": @{  }, @"channelId": @"", @"serviceUrl": @"", @"locale": @"" }, @"code": @"", @"expiration": @"", @"importance": @"", @"deliveryMode": @"", @"listenFor": @[  ], @"textHighlights": @[ @{ @"text": @"", @"occurrence": @0 } ], @"semanticAction": @{ @"state": @"", @"id": @"", @"entities": @{  } } } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/conversations/:conversationId/activities/history"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/conversations/:conversationId/activities/history" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/conversations/:conversationId/activities/history",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'activities' => [
        [
                'type' => '',
                'id' => '',
                'timestamp' => '',
                'localTimestamp' => '',
                'localTimezone' => '',
                'callerId' => '',
                'serviceUrl' => '',
                'channelId' => '',
                'from' => [
                                'id' => '',
                                'name' => '',
                                'aadObjectId' => '',
                                'role' => ''
                ],
                'conversation' => [
                                'isGroup' => null,
                                'conversationType' => '',
                                'tenantId' => '',
                                'id' => '',
                                'name' => '',
                                'aadObjectId' => '',
                                'role' => ''
                ],
                'recipient' => [
                                
                ],
                'textFormat' => '',
                'attachmentLayout' => '',
                'membersAdded' => [
                                [
                                                                
                                ]
                ],
                'membersRemoved' => [
                                [
                                                                
                                ]
                ],
                'reactionsAdded' => [
                                [
                                                                'type' => ''
                                ]
                ],
                'reactionsRemoved' => [
                                [
                                                                
                                ]
                ],
                'topicName' => '',
                'historyDisclosed' => null,
                'locale' => '',
                'text' => '',
                'speak' => '',
                'inputHint' => '',
                'summary' => '',
                'suggestedActions' => [
                                'to' => [
                                                                
                                ],
                                'actions' => [
                                                                [
                                                                                                                                'type' => '',
                                                                                                                                'title' => '',
                                                                                                                                'image' => '',
                                                                                                                                'imageAltText' => '',
                                                                                                                                'text' => '',
                                                                                                                                'displayText' => '',
                                                                                                                                'value' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'channelData' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'attachments' => [
                                [
                                                                'contentType' => '',
                                                                'contentUrl' => '',
                                                                'content' => [
                                                                                                                                
                                                                ],
                                                                'name' => '',
                                                                'thumbnailUrl' => ''
                                ]
                ],
                'entities' => [
                                [
                                                                'type' => ''
                                ]
                ],
                'channelData' => [
                                
                ],
                'action' => '',
                'replyToId' => '',
                'label' => '',
                'valueType' => '',
                'value' => [
                                
                ],
                'name' => '',
                'relatesTo' => [
                                'activityId' => '',
                                'user' => [
                                                                
                                ],
                                'bot' => [
                                                                
                                ],
                                'conversation' => [
                                                                
                                ],
                                'channelId' => '',
                                'serviceUrl' => '',
                                'locale' => ''
                ],
                'code' => '',
                'expiration' => '',
                'importance' => '',
                'deliveryMode' => '',
                'listenFor' => [
                                
                ],
                'textHighlights' => [
                                [
                                                                'text' => '',
                                                                'occurrence' => 0
                                ]
                ],
                'semanticAction' => [
                                'state' => '',
                                'id' => '',
                                'entities' => [
                                                                
                                ]
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/conversations/:conversationId/activities/history', [
  'body' => '{
  "activities": [
    {
      "type": "",
      "id": "",
      "timestamp": "",
      "localTimestamp": "",
      "localTimezone": "",
      "callerId": "",
      "serviceUrl": "",
      "channelId": "",
      "from": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "conversation": {
        "isGroup": false,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "recipient": {},
      "textFormat": "",
      "attachmentLayout": "",
      "membersAdded": [
        {}
      ],
      "membersRemoved": [
        {}
      ],
      "reactionsAdded": [
        {
          "type": ""
        }
      ],
      "reactionsRemoved": [
        {}
      ],
      "topicName": "",
      "historyDisclosed": false,
      "locale": "",
      "text": "",
      "speak": "",
      "inputHint": "",
      "summary": "",
      "suggestedActions": {
        "to": [],
        "actions": [
          {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
          }
        ]
      },
      "attachments": [
        {
          "contentType": "",
          "contentUrl": "",
          "content": {},
          "name": "",
          "thumbnailUrl": ""
        }
      ],
      "entities": [
        {
          "type": ""
        }
      ],
      "channelData": {},
      "action": "",
      "replyToId": "",
      "label": "",
      "valueType": "",
      "value": {},
      "name": "",
      "relatesTo": {
        "activityId": "",
        "user": {},
        "bot": {},
        "conversation": {},
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
      },
      "code": "",
      "expiration": "",
      "importance": "",
      "deliveryMode": "",
      "listenFor": [],
      "textHighlights": [
        {
          "text": "",
          "occurrence": 0
        }
      ],
      "semanticAction": {
        "state": "",
        "id": "",
        "entities": {}
      }
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/conversations/:conversationId/activities/history');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'activities' => [
    [
        'type' => '',
        'id' => '',
        'timestamp' => '',
        'localTimestamp' => '',
        'localTimezone' => '',
        'callerId' => '',
        'serviceUrl' => '',
        'channelId' => '',
        'from' => [
                'id' => '',
                'name' => '',
                'aadObjectId' => '',
                'role' => ''
        ],
        'conversation' => [
                'isGroup' => null,
                'conversationType' => '',
                'tenantId' => '',
                'id' => '',
                'name' => '',
                'aadObjectId' => '',
                'role' => ''
        ],
        'recipient' => [
                
        ],
        'textFormat' => '',
        'attachmentLayout' => '',
        'membersAdded' => [
                [
                                
                ]
        ],
        'membersRemoved' => [
                [
                                
                ]
        ],
        'reactionsAdded' => [
                [
                                'type' => ''
                ]
        ],
        'reactionsRemoved' => [
                [
                                
                ]
        ],
        'topicName' => '',
        'historyDisclosed' => null,
        'locale' => '',
        'text' => '',
        'speak' => '',
        'inputHint' => '',
        'summary' => '',
        'suggestedActions' => [
                'to' => [
                                
                ],
                'actions' => [
                                [
                                                                'type' => '',
                                                                'title' => '',
                                                                'image' => '',
                                                                'imageAltText' => '',
                                                                'text' => '',
                                                                'displayText' => '',
                                                                'value' => [
                                                                                                                                
                                                                ],
                                                                'channelData' => [
                                                                                                                                
                                                                ]
                                ]
                ]
        ],
        'attachments' => [
                [
                                'contentType' => '',
                                'contentUrl' => '',
                                'content' => [
                                                                
                                ],
                                'name' => '',
                                'thumbnailUrl' => ''
                ]
        ],
        'entities' => [
                [
                                'type' => ''
                ]
        ],
        'channelData' => [
                
        ],
        'action' => '',
        'replyToId' => '',
        'label' => '',
        'valueType' => '',
        'value' => [
                
        ],
        'name' => '',
        'relatesTo' => [
                'activityId' => '',
                'user' => [
                                
                ],
                'bot' => [
                                
                ],
                'conversation' => [
                                
                ],
                'channelId' => '',
                'serviceUrl' => '',
                'locale' => ''
        ],
        'code' => '',
        'expiration' => '',
        'importance' => '',
        'deliveryMode' => '',
        'listenFor' => [
                
        ],
        'textHighlights' => [
                [
                                'text' => '',
                                'occurrence' => 0
                ]
        ],
        'semanticAction' => [
                'state' => '',
                'id' => '',
                'entities' => [
                                
                ]
        ]
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'activities' => [
    [
        'type' => '',
        'id' => '',
        'timestamp' => '',
        'localTimestamp' => '',
        'localTimezone' => '',
        'callerId' => '',
        'serviceUrl' => '',
        'channelId' => '',
        'from' => [
                'id' => '',
                'name' => '',
                'aadObjectId' => '',
                'role' => ''
        ],
        'conversation' => [
                'isGroup' => null,
                'conversationType' => '',
                'tenantId' => '',
                'id' => '',
                'name' => '',
                'aadObjectId' => '',
                'role' => ''
        ],
        'recipient' => [
                
        ],
        'textFormat' => '',
        'attachmentLayout' => '',
        'membersAdded' => [
                [
                                
                ]
        ],
        'membersRemoved' => [
                [
                                
                ]
        ],
        'reactionsAdded' => [
                [
                                'type' => ''
                ]
        ],
        'reactionsRemoved' => [
                [
                                
                ]
        ],
        'topicName' => '',
        'historyDisclosed' => null,
        'locale' => '',
        'text' => '',
        'speak' => '',
        'inputHint' => '',
        'summary' => '',
        'suggestedActions' => [
                'to' => [
                                
                ],
                'actions' => [
                                [
                                                                'type' => '',
                                                                'title' => '',
                                                                'image' => '',
                                                                'imageAltText' => '',
                                                                'text' => '',
                                                                'displayText' => '',
                                                                'value' => [
                                                                                                                                
                                                                ],
                                                                'channelData' => [
                                                                                                                                
                                                                ]
                                ]
                ]
        ],
        'attachments' => [
                [
                                'contentType' => '',
                                'contentUrl' => '',
                                'content' => [
                                                                
                                ],
                                'name' => '',
                                'thumbnailUrl' => ''
                ]
        ],
        'entities' => [
                [
                                'type' => ''
                ]
        ],
        'channelData' => [
                
        ],
        'action' => '',
        'replyToId' => '',
        'label' => '',
        'valueType' => '',
        'value' => [
                
        ],
        'name' => '',
        'relatesTo' => [
                'activityId' => '',
                'user' => [
                                
                ],
                'bot' => [
                                
                ],
                'conversation' => [
                                
                ],
                'channelId' => '',
                'serviceUrl' => '',
                'locale' => ''
        ],
        'code' => '',
        'expiration' => '',
        'importance' => '',
        'deliveryMode' => '',
        'listenFor' => [
                
        ],
        'textHighlights' => [
                [
                                'text' => '',
                                'occurrence' => 0
                ]
        ],
        'semanticAction' => [
                'state' => '',
                'id' => '',
                'entities' => [
                                
                ]
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/conversations/:conversationId/activities/history');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/conversations/:conversationId/activities/history' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "activities": [
    {
      "type": "",
      "id": "",
      "timestamp": "",
      "localTimestamp": "",
      "localTimezone": "",
      "callerId": "",
      "serviceUrl": "",
      "channelId": "",
      "from": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "conversation": {
        "isGroup": false,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "recipient": {},
      "textFormat": "",
      "attachmentLayout": "",
      "membersAdded": [
        {}
      ],
      "membersRemoved": [
        {}
      ],
      "reactionsAdded": [
        {
          "type": ""
        }
      ],
      "reactionsRemoved": [
        {}
      ],
      "topicName": "",
      "historyDisclosed": false,
      "locale": "",
      "text": "",
      "speak": "",
      "inputHint": "",
      "summary": "",
      "suggestedActions": {
        "to": [],
        "actions": [
          {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
          }
        ]
      },
      "attachments": [
        {
          "contentType": "",
          "contentUrl": "",
          "content": {},
          "name": "",
          "thumbnailUrl": ""
        }
      ],
      "entities": [
        {
          "type": ""
        }
      ],
      "channelData": {},
      "action": "",
      "replyToId": "",
      "label": "",
      "valueType": "",
      "value": {},
      "name": "",
      "relatesTo": {
        "activityId": "",
        "user": {},
        "bot": {},
        "conversation": {},
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
      },
      "code": "",
      "expiration": "",
      "importance": "",
      "deliveryMode": "",
      "listenFor": [],
      "textHighlights": [
        {
          "text": "",
          "occurrence": 0
        }
      ],
      "semanticAction": {
        "state": "",
        "id": "",
        "entities": {}
      }
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/conversations/:conversationId/activities/history' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "activities": [
    {
      "type": "",
      "id": "",
      "timestamp": "",
      "localTimestamp": "",
      "localTimezone": "",
      "callerId": "",
      "serviceUrl": "",
      "channelId": "",
      "from": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "conversation": {
        "isGroup": false,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "recipient": {},
      "textFormat": "",
      "attachmentLayout": "",
      "membersAdded": [
        {}
      ],
      "membersRemoved": [
        {}
      ],
      "reactionsAdded": [
        {
          "type": ""
        }
      ],
      "reactionsRemoved": [
        {}
      ],
      "topicName": "",
      "historyDisclosed": false,
      "locale": "",
      "text": "",
      "speak": "",
      "inputHint": "",
      "summary": "",
      "suggestedActions": {
        "to": [],
        "actions": [
          {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
          }
        ]
      },
      "attachments": [
        {
          "contentType": "",
          "contentUrl": "",
          "content": {},
          "name": "",
          "thumbnailUrl": ""
        }
      ],
      "entities": [
        {
          "type": ""
        }
      ],
      "channelData": {},
      "action": "",
      "replyToId": "",
      "label": "",
      "valueType": "",
      "value": {},
      "name": "",
      "relatesTo": {
        "activityId": "",
        "user": {},
        "bot": {},
        "conversation": {},
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
      },
      "code": "",
      "expiration": "",
      "importance": "",
      "deliveryMode": "",
      "listenFor": [],
      "textHighlights": [
        {
          "text": "",
          "occurrence": 0
        }
      ],
      "semanticAction": {
        "state": "",
        "id": "",
        "entities": {}
      }
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/conversations/:conversationId/activities/history", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/conversations/:conversationId/activities/history"

payload = { "activities": [
        {
            "type": "",
            "id": "",
            "timestamp": "",
            "localTimestamp": "",
            "localTimezone": "",
            "callerId": "",
            "serviceUrl": "",
            "channelId": "",
            "from": {
                "id": "",
                "name": "",
                "aadObjectId": "",
                "role": ""
            },
            "conversation": {
                "isGroup": False,
                "conversationType": "",
                "tenantId": "",
                "id": "",
                "name": "",
                "aadObjectId": "",
                "role": ""
            },
            "recipient": {},
            "textFormat": "",
            "attachmentLayout": "",
            "membersAdded": [{}],
            "membersRemoved": [{}],
            "reactionsAdded": [{ "type": "" }],
            "reactionsRemoved": [{}],
            "topicName": "",
            "historyDisclosed": False,
            "locale": "",
            "text": "",
            "speak": "",
            "inputHint": "",
            "summary": "",
            "suggestedActions": {
                "to": [],
                "actions": [
                    {
                        "type": "",
                        "title": "",
                        "image": "",
                        "imageAltText": "",
                        "text": "",
                        "displayText": "",
                        "value": {},
                        "channelData": {}
                    }
                ]
            },
            "attachments": [
                {
                    "contentType": "",
                    "contentUrl": "",
                    "content": {},
                    "name": "",
                    "thumbnailUrl": ""
                }
            ],
            "entities": [{ "type": "" }],
            "channelData": {},
            "action": "",
            "replyToId": "",
            "label": "",
            "valueType": "",
            "value": {},
            "name": "",
            "relatesTo": {
                "activityId": "",
                "user": {},
                "bot": {},
                "conversation": {},
                "channelId": "",
                "serviceUrl": "",
                "locale": ""
            },
            "code": "",
            "expiration": "",
            "importance": "",
            "deliveryMode": "",
            "listenFor": [],
            "textHighlights": [
                {
                    "text": "",
                    "occurrence": 0
                }
            ],
            "semanticAction": {
                "state": "",
                "id": "",
                "entities": {}
            }
        }
    ] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/conversations/:conversationId/activities/history"

payload <- "{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/conversations/:conversationId/activities/history")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/conversations/:conversationId/activities/history') do |req|
  req.body = "{\n  \"activities\": [\n    {\n      \"type\": \"\",\n      \"id\": \"\",\n      \"timestamp\": \"\",\n      \"localTimestamp\": \"\",\n      \"localTimezone\": \"\",\n      \"callerId\": \"\",\n      \"serviceUrl\": \"\",\n      \"channelId\": \"\",\n      \"from\": {\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"conversation\": {\n        \"isGroup\": false,\n        \"conversationType\": \"\",\n        \"tenantId\": \"\",\n        \"id\": \"\",\n        \"name\": \"\",\n        \"aadObjectId\": \"\",\n        \"role\": \"\"\n      },\n      \"recipient\": {},\n      \"textFormat\": \"\",\n      \"attachmentLayout\": \"\",\n      \"membersAdded\": [\n        {}\n      ],\n      \"membersRemoved\": [\n        {}\n      ],\n      \"reactionsAdded\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"reactionsRemoved\": [\n        {}\n      ],\n      \"topicName\": \"\",\n      \"historyDisclosed\": false,\n      \"locale\": \"\",\n      \"text\": \"\",\n      \"speak\": \"\",\n      \"inputHint\": \"\",\n      \"summary\": \"\",\n      \"suggestedActions\": {\n        \"to\": [],\n        \"actions\": [\n          {\n            \"type\": \"\",\n            \"title\": \"\",\n            \"image\": \"\",\n            \"imageAltText\": \"\",\n            \"text\": \"\",\n            \"displayText\": \"\",\n            \"value\": {},\n            \"channelData\": {}\n          }\n        ]\n      },\n      \"attachments\": [\n        {\n          \"contentType\": \"\",\n          \"contentUrl\": \"\",\n          \"content\": {},\n          \"name\": \"\",\n          \"thumbnailUrl\": \"\"\n        }\n      ],\n      \"entities\": [\n        {\n          \"type\": \"\"\n        }\n      ],\n      \"channelData\": {},\n      \"action\": \"\",\n      \"replyToId\": \"\",\n      \"label\": \"\",\n      \"valueType\": \"\",\n      \"value\": {},\n      \"name\": \"\",\n      \"relatesTo\": {\n        \"activityId\": \"\",\n        \"user\": {},\n        \"bot\": {},\n        \"conversation\": {},\n        \"channelId\": \"\",\n        \"serviceUrl\": \"\",\n        \"locale\": \"\"\n      },\n      \"code\": \"\",\n      \"expiration\": \"\",\n      \"importance\": \"\",\n      \"deliveryMode\": \"\",\n      \"listenFor\": [],\n      \"textHighlights\": [\n        {\n          \"text\": \"\",\n          \"occurrence\": 0\n        }\n      ],\n      \"semanticAction\": {\n        \"state\": \"\",\n        \"id\": \"\",\n        \"entities\": {}\n      }\n    }\n  ]\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/conversations/:conversationId/activities/history";

    let payload = json!({"activities": (
            json!({
                "type": "",
                "id": "",
                "timestamp": "",
                "localTimestamp": "",
                "localTimezone": "",
                "callerId": "",
                "serviceUrl": "",
                "channelId": "",
                "from": json!({
                    "id": "",
                    "name": "",
                    "aadObjectId": "",
                    "role": ""
                }),
                "conversation": json!({
                    "isGroup": false,
                    "conversationType": "",
                    "tenantId": "",
                    "id": "",
                    "name": "",
                    "aadObjectId": "",
                    "role": ""
                }),
                "recipient": json!({}),
                "textFormat": "",
                "attachmentLayout": "",
                "membersAdded": (json!({})),
                "membersRemoved": (json!({})),
                "reactionsAdded": (json!({"type": ""})),
                "reactionsRemoved": (json!({})),
                "topicName": "",
                "historyDisclosed": false,
                "locale": "",
                "text": "",
                "speak": "",
                "inputHint": "",
                "summary": "",
                "suggestedActions": json!({
                    "to": (),
                    "actions": (
                        json!({
                            "type": "",
                            "title": "",
                            "image": "",
                            "imageAltText": "",
                            "text": "",
                            "displayText": "",
                            "value": json!({}),
                            "channelData": json!({})
                        })
                    )
                }),
                "attachments": (
                    json!({
                        "contentType": "",
                        "contentUrl": "",
                        "content": json!({}),
                        "name": "",
                        "thumbnailUrl": ""
                    })
                ),
                "entities": (json!({"type": ""})),
                "channelData": json!({}),
                "action": "",
                "replyToId": "",
                "label": "",
                "valueType": "",
                "value": json!({}),
                "name": "",
                "relatesTo": json!({
                    "activityId": "",
                    "user": json!({}),
                    "bot": json!({}),
                    "conversation": json!({}),
                    "channelId": "",
                    "serviceUrl": "",
                    "locale": ""
                }),
                "code": "",
                "expiration": "",
                "importance": "",
                "deliveryMode": "",
                "listenFor": (),
                "textHighlights": (
                    json!({
                        "text": "",
                        "occurrence": 0
                    })
                ),
                "semanticAction": json!({
                    "state": "",
                    "id": "",
                    "entities": json!({})
                })
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/conversations/:conversationId/activities/history \
  --header 'content-type: application/json' \
  --data '{
  "activities": [
    {
      "type": "",
      "id": "",
      "timestamp": "",
      "localTimestamp": "",
      "localTimezone": "",
      "callerId": "",
      "serviceUrl": "",
      "channelId": "",
      "from": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "conversation": {
        "isGroup": false,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "recipient": {},
      "textFormat": "",
      "attachmentLayout": "",
      "membersAdded": [
        {}
      ],
      "membersRemoved": [
        {}
      ],
      "reactionsAdded": [
        {
          "type": ""
        }
      ],
      "reactionsRemoved": [
        {}
      ],
      "topicName": "",
      "historyDisclosed": false,
      "locale": "",
      "text": "",
      "speak": "",
      "inputHint": "",
      "summary": "",
      "suggestedActions": {
        "to": [],
        "actions": [
          {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
          }
        ]
      },
      "attachments": [
        {
          "contentType": "",
          "contentUrl": "",
          "content": {},
          "name": "",
          "thumbnailUrl": ""
        }
      ],
      "entities": [
        {
          "type": ""
        }
      ],
      "channelData": {},
      "action": "",
      "replyToId": "",
      "label": "",
      "valueType": "",
      "value": {},
      "name": "",
      "relatesTo": {
        "activityId": "",
        "user": {},
        "bot": {},
        "conversation": {},
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
      },
      "code": "",
      "expiration": "",
      "importance": "",
      "deliveryMode": "",
      "listenFor": [],
      "textHighlights": [
        {
          "text": "",
          "occurrence": 0
        }
      ],
      "semanticAction": {
        "state": "",
        "id": "",
        "entities": {}
      }
    }
  ]
}'
echo '{
  "activities": [
    {
      "type": "",
      "id": "",
      "timestamp": "",
      "localTimestamp": "",
      "localTimezone": "",
      "callerId": "",
      "serviceUrl": "",
      "channelId": "",
      "from": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "conversation": {
        "isGroup": false,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      },
      "recipient": {},
      "textFormat": "",
      "attachmentLayout": "",
      "membersAdded": [
        {}
      ],
      "membersRemoved": [
        {}
      ],
      "reactionsAdded": [
        {
          "type": ""
        }
      ],
      "reactionsRemoved": [
        {}
      ],
      "topicName": "",
      "historyDisclosed": false,
      "locale": "",
      "text": "",
      "speak": "",
      "inputHint": "",
      "summary": "",
      "suggestedActions": {
        "to": [],
        "actions": [
          {
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": {},
            "channelData": {}
          }
        ]
      },
      "attachments": [
        {
          "contentType": "",
          "contentUrl": "",
          "content": {},
          "name": "",
          "thumbnailUrl": ""
        }
      ],
      "entities": [
        {
          "type": ""
        }
      ],
      "channelData": {},
      "action": "",
      "replyToId": "",
      "label": "",
      "valueType": "",
      "value": {},
      "name": "",
      "relatesTo": {
        "activityId": "",
        "user": {},
        "bot": {},
        "conversation": {},
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
      },
      "code": "",
      "expiration": "",
      "importance": "",
      "deliveryMode": "",
      "listenFor": [],
      "textHighlights": [
        {
          "text": "",
          "occurrence": 0
        }
      ],
      "semanticAction": {
        "state": "",
        "id": "",
        "entities": {}
      }
    }
  ]
}' |  \
  http POST {{baseUrl}}/v3/conversations/:conversationId/activities/history \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "activities": [\n    {\n      "type": "",\n      "id": "",\n      "timestamp": "",\n      "localTimestamp": "",\n      "localTimezone": "",\n      "callerId": "",\n      "serviceUrl": "",\n      "channelId": "",\n      "from": {\n        "id": "",\n        "name": "",\n        "aadObjectId": "",\n        "role": ""\n      },\n      "conversation": {\n        "isGroup": false,\n        "conversationType": "",\n        "tenantId": "",\n        "id": "",\n        "name": "",\n        "aadObjectId": "",\n        "role": ""\n      },\n      "recipient": {},\n      "textFormat": "",\n      "attachmentLayout": "",\n      "membersAdded": [\n        {}\n      ],\n      "membersRemoved": [\n        {}\n      ],\n      "reactionsAdded": [\n        {\n          "type": ""\n        }\n      ],\n      "reactionsRemoved": [\n        {}\n      ],\n      "topicName": "",\n      "historyDisclosed": false,\n      "locale": "",\n      "text": "",\n      "speak": "",\n      "inputHint": "",\n      "summary": "",\n      "suggestedActions": {\n        "to": [],\n        "actions": [\n          {\n            "type": "",\n            "title": "",\n            "image": "",\n            "imageAltText": "",\n            "text": "",\n            "displayText": "",\n            "value": {},\n            "channelData": {}\n          }\n        ]\n      },\n      "attachments": [\n        {\n          "contentType": "",\n          "contentUrl": "",\n          "content": {},\n          "name": "",\n          "thumbnailUrl": ""\n        }\n      ],\n      "entities": [\n        {\n          "type": ""\n        }\n      ],\n      "channelData": {},\n      "action": "",\n      "replyToId": "",\n      "label": "",\n      "valueType": "",\n      "value": {},\n      "name": "",\n      "relatesTo": {\n        "activityId": "",\n        "user": {},\n        "bot": {},\n        "conversation": {},\n        "channelId": "",\n        "serviceUrl": "",\n        "locale": ""\n      },\n      "code": "",\n      "expiration": "",\n      "importance": "",\n      "deliveryMode": "",\n      "listenFor": [],\n      "textHighlights": [\n        {\n          "text": "",\n          "occurrence": 0\n        }\n      ],\n      "semanticAction": {\n        "state": "",\n        "id": "",\n        "entities": {}\n      }\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/v3/conversations/:conversationId/activities/history
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["activities": [
    [
      "type": "",
      "id": "",
      "timestamp": "",
      "localTimestamp": "",
      "localTimezone": "",
      "callerId": "",
      "serviceUrl": "",
      "channelId": "",
      "from": [
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      ],
      "conversation": [
        "isGroup": false,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
      ],
      "recipient": [],
      "textFormat": "",
      "attachmentLayout": "",
      "membersAdded": [[]],
      "membersRemoved": [[]],
      "reactionsAdded": [["type": ""]],
      "reactionsRemoved": [[]],
      "topicName": "",
      "historyDisclosed": false,
      "locale": "",
      "text": "",
      "speak": "",
      "inputHint": "",
      "summary": "",
      "suggestedActions": [
        "to": [],
        "actions": [
          [
            "type": "",
            "title": "",
            "image": "",
            "imageAltText": "",
            "text": "",
            "displayText": "",
            "value": [],
            "channelData": []
          ]
        ]
      ],
      "attachments": [
        [
          "contentType": "",
          "contentUrl": "",
          "content": [],
          "name": "",
          "thumbnailUrl": ""
        ]
      ],
      "entities": [["type": ""]],
      "channelData": [],
      "action": "",
      "replyToId": "",
      "label": "",
      "valueType": "",
      "value": [],
      "name": "",
      "relatesTo": [
        "activityId": "",
        "user": [],
        "bot": [],
        "conversation": [],
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
      ],
      "code": "",
      "expiration": "",
      "importance": "",
      "deliveryMode": "",
      "listenFor": [],
      "textHighlights": [
        [
          "text": "",
          "occurrence": 0
        ]
      ],
      "semanticAction": [
        "state": "",
        "id": "",
        "entities": []
      ]
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/conversations/:conversationId/activities/history")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST SendToConversation
{{baseUrl}}/v3/conversations/:conversationId/activities
QUERY PARAMS

conversationId
BODY json

{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/conversations/:conversationId/activities");

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  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/conversations/:conversationId/activities" {:content-type :json
                                                                                        :form-params {:type ""
                                                                                                      :id ""
                                                                                                      :timestamp ""
                                                                                                      :localTimestamp ""
                                                                                                      :localTimezone ""
                                                                                                      :callerId ""
                                                                                                      :serviceUrl ""
                                                                                                      :channelId ""
                                                                                                      :from {:id ""
                                                                                                             :name ""
                                                                                                             :aadObjectId ""
                                                                                                             :role ""}
                                                                                                      :conversation {:isGroup false
                                                                                                                     :conversationType ""
                                                                                                                     :tenantId ""
                                                                                                                     :id ""
                                                                                                                     :name ""
                                                                                                                     :aadObjectId ""
                                                                                                                     :role ""}
                                                                                                      :recipient {}
                                                                                                      :textFormat ""
                                                                                                      :attachmentLayout ""
                                                                                                      :membersAdded [{}]
                                                                                                      :membersRemoved [{}]
                                                                                                      :reactionsAdded [{:type ""}]
                                                                                                      :reactionsRemoved [{}]
                                                                                                      :topicName ""
                                                                                                      :historyDisclosed false
                                                                                                      :locale ""
                                                                                                      :text ""
                                                                                                      :speak ""
                                                                                                      :inputHint ""
                                                                                                      :summary ""
                                                                                                      :suggestedActions {:to []
                                                                                                                         :actions [{:type ""
                                                                                                                                    :title ""
                                                                                                                                    :image ""
                                                                                                                                    :imageAltText ""
                                                                                                                                    :text ""
                                                                                                                                    :displayText ""
                                                                                                                                    :value {}
                                                                                                                                    :channelData {}}]}
                                                                                                      :attachments [{:contentType ""
                                                                                                                     :contentUrl ""
                                                                                                                     :content {}
                                                                                                                     :name ""
                                                                                                                     :thumbnailUrl ""}]
                                                                                                      :entities [{:type ""}]
                                                                                                      :channelData {}
                                                                                                      :action ""
                                                                                                      :replyToId ""
                                                                                                      :label ""
                                                                                                      :valueType ""
                                                                                                      :value {}
                                                                                                      :name ""
                                                                                                      :relatesTo {:activityId ""
                                                                                                                  :user {}
                                                                                                                  :bot {}
                                                                                                                  :conversation {}
                                                                                                                  :channelId ""
                                                                                                                  :serviceUrl ""
                                                                                                                  :locale ""}
                                                                                                      :code ""
                                                                                                      :expiration ""
                                                                                                      :importance ""
                                                                                                      :deliveryMode ""
                                                                                                      :listenFor []
                                                                                                      :textHighlights [{:text ""
                                                                                                                        :occurrence 0}]
                                                                                                      :semanticAction {:state ""
                                                                                                                       :id ""
                                                                                                                       :entities {}}}})
require "http/client"

url = "{{baseUrl}}/v3/conversations/:conversationId/activities"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/conversations/:conversationId/activities"),
    Content = new StringContent("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3/conversations/:conversationId/activities");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/conversations/:conversationId/activities"

	payload := strings.NewReader("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/conversations/:conversationId/activities HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1745

{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/conversations/:conversationId/activities")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/conversations/:conversationId/activities"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/conversations/:conversationId/activities")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/conversations/:conversationId/activities")
  .header("content-type", "application/json")
  .body("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")
  .asString();
const data = JSON.stringify({
  type: '',
  id: '',
  timestamp: '',
  localTimestamp: '',
  localTimezone: '',
  callerId: '',
  serviceUrl: '',
  channelId: '',
  from: {
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  conversation: {
    isGroup: false,
    conversationType: '',
    tenantId: '',
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  recipient: {},
  textFormat: '',
  attachmentLayout: '',
  membersAdded: [
    {}
  ],
  membersRemoved: [
    {}
  ],
  reactionsAdded: [
    {
      type: ''
    }
  ],
  reactionsRemoved: [
    {}
  ],
  topicName: '',
  historyDisclosed: false,
  locale: '',
  text: '',
  speak: '',
  inputHint: '',
  summary: '',
  suggestedActions: {
    to: [],
    actions: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ]
  },
  attachments: [
    {
      contentType: '',
      contentUrl: '',
      content: {},
      name: '',
      thumbnailUrl: ''
    }
  ],
  entities: [
    {
      type: ''
    }
  ],
  channelData: {},
  action: '',
  replyToId: '',
  label: '',
  valueType: '',
  value: {},
  name: '',
  relatesTo: {
    activityId: '',
    user: {},
    bot: {},
    conversation: {},
    channelId: '',
    serviceUrl: '',
    locale: ''
  },
  code: '',
  expiration: '',
  importance: '',
  deliveryMode: '',
  listenFor: [],
  textHighlights: [
    {
      text: '',
      occurrence: 0
    }
  ],
  semanticAction: {
    state: '',
    id: '',
    entities: {}
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/conversations/:conversationId/activities');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/conversations/:conversationId/activities',
  headers: {'content-type': 'application/json'},
  data: {
    type: '',
    id: '',
    timestamp: '',
    localTimestamp: '',
    localTimezone: '',
    callerId: '',
    serviceUrl: '',
    channelId: '',
    from: {id: '', name: '', aadObjectId: '', role: ''},
    conversation: {
      isGroup: false,
      conversationType: '',
      tenantId: '',
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    recipient: {},
    textFormat: '',
    attachmentLayout: '',
    membersAdded: [{}],
    membersRemoved: [{}],
    reactionsAdded: [{type: ''}],
    reactionsRemoved: [{}],
    topicName: '',
    historyDisclosed: false,
    locale: '',
    text: '',
    speak: '',
    inputHint: '',
    summary: '',
    suggestedActions: {
      to: [],
      actions: [
        {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      ]
    },
    attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
    entities: [{type: ''}],
    channelData: {},
    action: '',
    replyToId: '',
    label: '',
    valueType: '',
    value: {},
    name: '',
    relatesTo: {
      activityId: '',
      user: {},
      bot: {},
      conversation: {},
      channelId: '',
      serviceUrl: '',
      locale: ''
    },
    code: '',
    expiration: '',
    importance: '',
    deliveryMode: '',
    listenFor: [],
    textHighlights: [{text: '', occurrence: 0}],
    semanticAction: {state: '', id: '', entities: {}}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/conversations/:conversationId/activities';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"type":"","id":"","timestamp":"","localTimestamp":"","localTimezone":"","callerId":"","serviceUrl":"","channelId":"","from":{"id":"","name":"","aadObjectId":"","role":""},"conversation":{"isGroup":false,"conversationType":"","tenantId":"","id":"","name":"","aadObjectId":"","role":""},"recipient":{},"textFormat":"","attachmentLayout":"","membersAdded":[{}],"membersRemoved":[{}],"reactionsAdded":[{"type":""}],"reactionsRemoved":[{}],"topicName":"","historyDisclosed":false,"locale":"","text":"","speak":"","inputHint":"","summary":"","suggestedActions":{"to":[],"actions":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}]},"attachments":[{"contentType":"","contentUrl":"","content":{},"name":"","thumbnailUrl":""}],"entities":[{"type":""}],"channelData":{},"action":"","replyToId":"","label":"","valueType":"","value":{},"name":"","relatesTo":{"activityId":"","user":{},"bot":{},"conversation":{},"channelId":"","serviceUrl":"","locale":""},"code":"","expiration":"","importance":"","deliveryMode":"","listenFor":[],"textHighlights":[{"text":"","occurrence":0}],"semanticAction":{"state":"","id":"","entities":{}}}'
};

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}}/v3/conversations/:conversationId/activities',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "type": "",\n  "id": "",\n  "timestamp": "",\n  "localTimestamp": "",\n  "localTimezone": "",\n  "callerId": "",\n  "serviceUrl": "",\n  "channelId": "",\n  "from": {\n    "id": "",\n    "name": "",\n    "aadObjectId": "",\n    "role": ""\n  },\n  "conversation": {\n    "isGroup": false,\n    "conversationType": "",\n    "tenantId": "",\n    "id": "",\n    "name": "",\n    "aadObjectId": "",\n    "role": ""\n  },\n  "recipient": {},\n  "textFormat": "",\n  "attachmentLayout": "",\n  "membersAdded": [\n    {}\n  ],\n  "membersRemoved": [\n    {}\n  ],\n  "reactionsAdded": [\n    {\n      "type": ""\n    }\n  ],\n  "reactionsRemoved": [\n    {}\n  ],\n  "topicName": "",\n  "historyDisclosed": false,\n  "locale": "",\n  "text": "",\n  "speak": "",\n  "inputHint": "",\n  "summary": "",\n  "suggestedActions": {\n    "to": [],\n    "actions": [\n      {\n        "type": "",\n        "title": "",\n        "image": "",\n        "imageAltText": "",\n        "text": "",\n        "displayText": "",\n        "value": {},\n        "channelData": {}\n      }\n    ]\n  },\n  "attachments": [\n    {\n      "contentType": "",\n      "contentUrl": "",\n      "content": {},\n      "name": "",\n      "thumbnailUrl": ""\n    }\n  ],\n  "entities": [\n    {\n      "type": ""\n    }\n  ],\n  "channelData": {},\n  "action": "",\n  "replyToId": "",\n  "label": "",\n  "valueType": "",\n  "value": {},\n  "name": "",\n  "relatesTo": {\n    "activityId": "",\n    "user": {},\n    "bot": {},\n    "conversation": {},\n    "channelId": "",\n    "serviceUrl": "",\n    "locale": ""\n  },\n  "code": "",\n  "expiration": "",\n  "importance": "",\n  "deliveryMode": "",\n  "listenFor": [],\n  "textHighlights": [\n    {\n      "text": "",\n      "occurrence": 0\n    }\n  ],\n  "semanticAction": {\n    "state": "",\n    "id": "",\n    "entities": {}\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/conversations/:conversationId/activities")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/conversations/:conversationId/activities',
  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({
  type: '',
  id: '',
  timestamp: '',
  localTimestamp: '',
  localTimezone: '',
  callerId: '',
  serviceUrl: '',
  channelId: '',
  from: {id: '', name: '', aadObjectId: '', role: ''},
  conversation: {
    isGroup: false,
    conversationType: '',
    tenantId: '',
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  recipient: {},
  textFormat: '',
  attachmentLayout: '',
  membersAdded: [{}],
  membersRemoved: [{}],
  reactionsAdded: [{type: ''}],
  reactionsRemoved: [{}],
  topicName: '',
  historyDisclosed: false,
  locale: '',
  text: '',
  speak: '',
  inputHint: '',
  summary: '',
  suggestedActions: {
    to: [],
    actions: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ]
  },
  attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
  entities: [{type: ''}],
  channelData: {},
  action: '',
  replyToId: '',
  label: '',
  valueType: '',
  value: {},
  name: '',
  relatesTo: {
    activityId: '',
    user: {},
    bot: {},
    conversation: {},
    channelId: '',
    serviceUrl: '',
    locale: ''
  },
  code: '',
  expiration: '',
  importance: '',
  deliveryMode: '',
  listenFor: [],
  textHighlights: [{text: '', occurrence: 0}],
  semanticAction: {state: '', id: '', entities: {}}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/conversations/:conversationId/activities',
  headers: {'content-type': 'application/json'},
  body: {
    type: '',
    id: '',
    timestamp: '',
    localTimestamp: '',
    localTimezone: '',
    callerId: '',
    serviceUrl: '',
    channelId: '',
    from: {id: '', name: '', aadObjectId: '', role: ''},
    conversation: {
      isGroup: false,
      conversationType: '',
      tenantId: '',
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    recipient: {},
    textFormat: '',
    attachmentLayout: '',
    membersAdded: [{}],
    membersRemoved: [{}],
    reactionsAdded: [{type: ''}],
    reactionsRemoved: [{}],
    topicName: '',
    historyDisclosed: false,
    locale: '',
    text: '',
    speak: '',
    inputHint: '',
    summary: '',
    suggestedActions: {
      to: [],
      actions: [
        {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      ]
    },
    attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
    entities: [{type: ''}],
    channelData: {},
    action: '',
    replyToId: '',
    label: '',
    valueType: '',
    value: {},
    name: '',
    relatesTo: {
      activityId: '',
      user: {},
      bot: {},
      conversation: {},
      channelId: '',
      serviceUrl: '',
      locale: ''
    },
    code: '',
    expiration: '',
    importance: '',
    deliveryMode: '',
    listenFor: [],
    textHighlights: [{text: '', occurrence: 0}],
    semanticAction: {state: '', id: '', entities: {}}
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/conversations/:conversationId/activities');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  type: '',
  id: '',
  timestamp: '',
  localTimestamp: '',
  localTimezone: '',
  callerId: '',
  serviceUrl: '',
  channelId: '',
  from: {
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  conversation: {
    isGroup: false,
    conversationType: '',
    tenantId: '',
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  recipient: {},
  textFormat: '',
  attachmentLayout: '',
  membersAdded: [
    {}
  ],
  membersRemoved: [
    {}
  ],
  reactionsAdded: [
    {
      type: ''
    }
  ],
  reactionsRemoved: [
    {}
  ],
  topicName: '',
  historyDisclosed: false,
  locale: '',
  text: '',
  speak: '',
  inputHint: '',
  summary: '',
  suggestedActions: {
    to: [],
    actions: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ]
  },
  attachments: [
    {
      contentType: '',
      contentUrl: '',
      content: {},
      name: '',
      thumbnailUrl: ''
    }
  ],
  entities: [
    {
      type: ''
    }
  ],
  channelData: {},
  action: '',
  replyToId: '',
  label: '',
  valueType: '',
  value: {},
  name: '',
  relatesTo: {
    activityId: '',
    user: {},
    bot: {},
    conversation: {},
    channelId: '',
    serviceUrl: '',
    locale: ''
  },
  code: '',
  expiration: '',
  importance: '',
  deliveryMode: '',
  listenFor: [],
  textHighlights: [
    {
      text: '',
      occurrence: 0
    }
  ],
  semanticAction: {
    state: '',
    id: '',
    entities: {}
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/conversations/:conversationId/activities',
  headers: {'content-type': 'application/json'},
  data: {
    type: '',
    id: '',
    timestamp: '',
    localTimestamp: '',
    localTimezone: '',
    callerId: '',
    serviceUrl: '',
    channelId: '',
    from: {id: '', name: '', aadObjectId: '', role: ''},
    conversation: {
      isGroup: false,
      conversationType: '',
      tenantId: '',
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    recipient: {},
    textFormat: '',
    attachmentLayout: '',
    membersAdded: [{}],
    membersRemoved: [{}],
    reactionsAdded: [{type: ''}],
    reactionsRemoved: [{}],
    topicName: '',
    historyDisclosed: false,
    locale: '',
    text: '',
    speak: '',
    inputHint: '',
    summary: '',
    suggestedActions: {
      to: [],
      actions: [
        {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      ]
    },
    attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
    entities: [{type: ''}],
    channelData: {},
    action: '',
    replyToId: '',
    label: '',
    valueType: '',
    value: {},
    name: '',
    relatesTo: {
      activityId: '',
      user: {},
      bot: {},
      conversation: {},
      channelId: '',
      serviceUrl: '',
      locale: ''
    },
    code: '',
    expiration: '',
    importance: '',
    deliveryMode: '',
    listenFor: [],
    textHighlights: [{text: '', occurrence: 0}],
    semanticAction: {state: '', id: '', entities: {}}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/conversations/:conversationId/activities';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"type":"","id":"","timestamp":"","localTimestamp":"","localTimezone":"","callerId":"","serviceUrl":"","channelId":"","from":{"id":"","name":"","aadObjectId":"","role":""},"conversation":{"isGroup":false,"conversationType":"","tenantId":"","id":"","name":"","aadObjectId":"","role":""},"recipient":{},"textFormat":"","attachmentLayout":"","membersAdded":[{}],"membersRemoved":[{}],"reactionsAdded":[{"type":""}],"reactionsRemoved":[{}],"topicName":"","historyDisclosed":false,"locale":"","text":"","speak":"","inputHint":"","summary":"","suggestedActions":{"to":[],"actions":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}]},"attachments":[{"contentType":"","contentUrl":"","content":{},"name":"","thumbnailUrl":""}],"entities":[{"type":""}],"channelData":{},"action":"","replyToId":"","label":"","valueType":"","value":{},"name":"","relatesTo":{"activityId":"","user":{},"bot":{},"conversation":{},"channelId":"","serviceUrl":"","locale":""},"code":"","expiration":"","importance":"","deliveryMode":"","listenFor":[],"textHighlights":[{"text":"","occurrence":0}],"semanticAction":{"state":"","id":"","entities":{}}}'
};

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 = @{ @"type": @"",
                              @"id": @"",
                              @"timestamp": @"",
                              @"localTimestamp": @"",
                              @"localTimezone": @"",
                              @"callerId": @"",
                              @"serviceUrl": @"",
                              @"channelId": @"",
                              @"from": @{ @"id": @"", @"name": @"", @"aadObjectId": @"", @"role": @"" },
                              @"conversation": @{ @"isGroup": @NO, @"conversationType": @"", @"tenantId": @"", @"id": @"", @"name": @"", @"aadObjectId": @"", @"role": @"" },
                              @"recipient": @{  },
                              @"textFormat": @"",
                              @"attachmentLayout": @"",
                              @"membersAdded": @[ @{  } ],
                              @"membersRemoved": @[ @{  } ],
                              @"reactionsAdded": @[ @{ @"type": @"" } ],
                              @"reactionsRemoved": @[ @{  } ],
                              @"topicName": @"",
                              @"historyDisclosed": @NO,
                              @"locale": @"",
                              @"text": @"",
                              @"speak": @"",
                              @"inputHint": @"",
                              @"summary": @"",
                              @"suggestedActions": @{ @"to": @[  ], @"actions": @[ @{ @"type": @"", @"title": @"", @"image": @"", @"imageAltText": @"", @"text": @"", @"displayText": @"", @"value": @{  }, @"channelData": @{  } } ] },
                              @"attachments": @[ @{ @"contentType": @"", @"contentUrl": @"", @"content": @{  }, @"name": @"", @"thumbnailUrl": @"" } ],
                              @"entities": @[ @{ @"type": @"" } ],
                              @"channelData": @{  },
                              @"action": @"",
                              @"replyToId": @"",
                              @"label": @"",
                              @"valueType": @"",
                              @"value": @{  },
                              @"name": @"",
                              @"relatesTo": @{ @"activityId": @"", @"user": @{  }, @"bot": @{  }, @"conversation": @{  }, @"channelId": @"", @"serviceUrl": @"", @"locale": @"" },
                              @"code": @"",
                              @"expiration": @"",
                              @"importance": @"",
                              @"deliveryMode": @"",
                              @"listenFor": @[  ],
                              @"textHighlights": @[ @{ @"text": @"", @"occurrence": @0 } ],
                              @"semanticAction": @{ @"state": @"", @"id": @"", @"entities": @{  } } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/conversations/:conversationId/activities"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/conversations/:conversationId/activities" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/conversations/:conversationId/activities",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'type' => '',
    'id' => '',
    'timestamp' => '',
    'localTimestamp' => '',
    'localTimezone' => '',
    'callerId' => '',
    'serviceUrl' => '',
    'channelId' => '',
    'from' => [
        'id' => '',
        'name' => '',
        'aadObjectId' => '',
        'role' => ''
    ],
    'conversation' => [
        'isGroup' => null,
        'conversationType' => '',
        'tenantId' => '',
        'id' => '',
        'name' => '',
        'aadObjectId' => '',
        'role' => ''
    ],
    'recipient' => [
        
    ],
    'textFormat' => '',
    'attachmentLayout' => '',
    'membersAdded' => [
        [
                
        ]
    ],
    'membersRemoved' => [
        [
                
        ]
    ],
    'reactionsAdded' => [
        [
                'type' => ''
        ]
    ],
    'reactionsRemoved' => [
        [
                
        ]
    ],
    'topicName' => '',
    'historyDisclosed' => null,
    'locale' => '',
    'text' => '',
    'speak' => '',
    'inputHint' => '',
    'summary' => '',
    'suggestedActions' => [
        'to' => [
                
        ],
        'actions' => [
                [
                                'type' => '',
                                'title' => '',
                                'image' => '',
                                'imageAltText' => '',
                                'text' => '',
                                'displayText' => '',
                                'value' => [
                                                                
                                ],
                                'channelData' => [
                                                                
                                ]
                ]
        ]
    ],
    'attachments' => [
        [
                'contentType' => '',
                'contentUrl' => '',
                'content' => [
                                
                ],
                'name' => '',
                'thumbnailUrl' => ''
        ]
    ],
    'entities' => [
        [
                'type' => ''
        ]
    ],
    'channelData' => [
        
    ],
    'action' => '',
    'replyToId' => '',
    'label' => '',
    'valueType' => '',
    'value' => [
        
    ],
    'name' => '',
    'relatesTo' => [
        'activityId' => '',
        'user' => [
                
        ],
        'bot' => [
                
        ],
        'conversation' => [
                
        ],
        'channelId' => '',
        'serviceUrl' => '',
        'locale' => ''
    ],
    'code' => '',
    'expiration' => '',
    'importance' => '',
    'deliveryMode' => '',
    'listenFor' => [
        
    ],
    'textHighlights' => [
        [
                'text' => '',
                'occurrence' => 0
        ]
    ],
    'semanticAction' => [
        'state' => '',
        'id' => '',
        'entities' => [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/conversations/:conversationId/activities', [
  'body' => '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/conversations/:conversationId/activities');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'type' => '',
  'id' => '',
  'timestamp' => '',
  'localTimestamp' => '',
  'localTimezone' => '',
  'callerId' => '',
  'serviceUrl' => '',
  'channelId' => '',
  'from' => [
    'id' => '',
    'name' => '',
    'aadObjectId' => '',
    'role' => ''
  ],
  'conversation' => [
    'isGroup' => null,
    'conversationType' => '',
    'tenantId' => '',
    'id' => '',
    'name' => '',
    'aadObjectId' => '',
    'role' => ''
  ],
  'recipient' => [
    
  ],
  'textFormat' => '',
  'attachmentLayout' => '',
  'membersAdded' => [
    [
        
    ]
  ],
  'membersRemoved' => [
    [
        
    ]
  ],
  'reactionsAdded' => [
    [
        'type' => ''
    ]
  ],
  'reactionsRemoved' => [
    [
        
    ]
  ],
  'topicName' => '',
  'historyDisclosed' => null,
  'locale' => '',
  'text' => '',
  'speak' => '',
  'inputHint' => '',
  'summary' => '',
  'suggestedActions' => [
    'to' => [
        
    ],
    'actions' => [
        [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ]
  ],
  'attachments' => [
    [
        'contentType' => '',
        'contentUrl' => '',
        'content' => [
                
        ],
        'name' => '',
        'thumbnailUrl' => ''
    ]
  ],
  'entities' => [
    [
        'type' => ''
    ]
  ],
  'channelData' => [
    
  ],
  'action' => '',
  'replyToId' => '',
  'label' => '',
  'valueType' => '',
  'value' => [
    
  ],
  'name' => '',
  'relatesTo' => [
    'activityId' => '',
    'user' => [
        
    ],
    'bot' => [
        
    ],
    'conversation' => [
        
    ],
    'channelId' => '',
    'serviceUrl' => '',
    'locale' => ''
  ],
  'code' => '',
  'expiration' => '',
  'importance' => '',
  'deliveryMode' => '',
  'listenFor' => [
    
  ],
  'textHighlights' => [
    [
        'text' => '',
        'occurrence' => 0
    ]
  ],
  'semanticAction' => [
    'state' => '',
    'id' => '',
    'entities' => [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'type' => '',
  'id' => '',
  'timestamp' => '',
  'localTimestamp' => '',
  'localTimezone' => '',
  'callerId' => '',
  'serviceUrl' => '',
  'channelId' => '',
  'from' => [
    'id' => '',
    'name' => '',
    'aadObjectId' => '',
    'role' => ''
  ],
  'conversation' => [
    'isGroup' => null,
    'conversationType' => '',
    'tenantId' => '',
    'id' => '',
    'name' => '',
    'aadObjectId' => '',
    'role' => ''
  ],
  'recipient' => [
    
  ],
  'textFormat' => '',
  'attachmentLayout' => '',
  'membersAdded' => [
    [
        
    ]
  ],
  'membersRemoved' => [
    [
        
    ]
  ],
  'reactionsAdded' => [
    [
        'type' => ''
    ]
  ],
  'reactionsRemoved' => [
    [
        
    ]
  ],
  'topicName' => '',
  'historyDisclosed' => null,
  'locale' => '',
  'text' => '',
  'speak' => '',
  'inputHint' => '',
  'summary' => '',
  'suggestedActions' => [
    'to' => [
        
    ],
    'actions' => [
        [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ]
  ],
  'attachments' => [
    [
        'contentType' => '',
        'contentUrl' => '',
        'content' => [
                
        ],
        'name' => '',
        'thumbnailUrl' => ''
    ]
  ],
  'entities' => [
    [
        'type' => ''
    ]
  ],
  'channelData' => [
    
  ],
  'action' => '',
  'replyToId' => '',
  'label' => '',
  'valueType' => '',
  'value' => [
    
  ],
  'name' => '',
  'relatesTo' => [
    'activityId' => '',
    'user' => [
        
    ],
    'bot' => [
        
    ],
    'conversation' => [
        
    ],
    'channelId' => '',
    'serviceUrl' => '',
    'locale' => ''
  ],
  'code' => '',
  'expiration' => '',
  'importance' => '',
  'deliveryMode' => '',
  'listenFor' => [
    
  ],
  'textHighlights' => [
    [
        'text' => '',
        'occurrence' => 0
    ]
  ],
  'semanticAction' => [
    'state' => '',
    'id' => '',
    'entities' => [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/conversations/:conversationId/activities');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/conversations/:conversationId/activities' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/conversations/:conversationId/activities' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/conversations/:conversationId/activities", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/conversations/:conversationId/activities"

payload = {
    "type": "",
    "id": "",
    "timestamp": "",
    "localTimestamp": "",
    "localTimezone": "",
    "callerId": "",
    "serviceUrl": "",
    "channelId": "",
    "from": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
    },
    "conversation": {
        "isGroup": False,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
    },
    "recipient": {},
    "textFormat": "",
    "attachmentLayout": "",
    "membersAdded": [{}],
    "membersRemoved": [{}],
    "reactionsAdded": [{ "type": "" }],
    "reactionsRemoved": [{}],
    "topicName": "",
    "historyDisclosed": False,
    "locale": "",
    "text": "",
    "speak": "",
    "inputHint": "",
    "summary": "",
    "suggestedActions": {
        "to": [],
        "actions": [
            {
                "type": "",
                "title": "",
                "image": "",
                "imageAltText": "",
                "text": "",
                "displayText": "",
                "value": {},
                "channelData": {}
            }
        ]
    },
    "attachments": [
        {
            "contentType": "",
            "contentUrl": "",
            "content": {},
            "name": "",
            "thumbnailUrl": ""
        }
    ],
    "entities": [{ "type": "" }],
    "channelData": {},
    "action": "",
    "replyToId": "",
    "label": "",
    "valueType": "",
    "value": {},
    "name": "",
    "relatesTo": {
        "activityId": "",
        "user": {},
        "bot": {},
        "conversation": {},
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
    },
    "code": "",
    "expiration": "",
    "importance": "",
    "deliveryMode": "",
    "listenFor": [],
    "textHighlights": [
        {
            "text": "",
            "occurrence": 0
        }
    ],
    "semanticAction": {
        "state": "",
        "id": "",
        "entities": {}
    }
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/conversations/:conversationId/activities"

payload <- "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/conversations/:conversationId/activities")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/conversations/:conversationId/activities') do |req|
  req.body = "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/conversations/:conversationId/activities";

    let payload = json!({
        "type": "",
        "id": "",
        "timestamp": "",
        "localTimestamp": "",
        "localTimezone": "",
        "callerId": "",
        "serviceUrl": "",
        "channelId": "",
        "from": json!({
            "id": "",
            "name": "",
            "aadObjectId": "",
            "role": ""
        }),
        "conversation": json!({
            "isGroup": false,
            "conversationType": "",
            "tenantId": "",
            "id": "",
            "name": "",
            "aadObjectId": "",
            "role": ""
        }),
        "recipient": json!({}),
        "textFormat": "",
        "attachmentLayout": "",
        "membersAdded": (json!({})),
        "membersRemoved": (json!({})),
        "reactionsAdded": (json!({"type": ""})),
        "reactionsRemoved": (json!({})),
        "topicName": "",
        "historyDisclosed": false,
        "locale": "",
        "text": "",
        "speak": "",
        "inputHint": "",
        "summary": "",
        "suggestedActions": json!({
            "to": (),
            "actions": (
                json!({
                    "type": "",
                    "title": "",
                    "image": "",
                    "imageAltText": "",
                    "text": "",
                    "displayText": "",
                    "value": json!({}),
                    "channelData": json!({})
                })
            )
        }),
        "attachments": (
            json!({
                "contentType": "",
                "contentUrl": "",
                "content": json!({}),
                "name": "",
                "thumbnailUrl": ""
            })
        ),
        "entities": (json!({"type": ""})),
        "channelData": json!({}),
        "action": "",
        "replyToId": "",
        "label": "",
        "valueType": "",
        "value": json!({}),
        "name": "",
        "relatesTo": json!({
            "activityId": "",
            "user": json!({}),
            "bot": json!({}),
            "conversation": json!({}),
            "channelId": "",
            "serviceUrl": "",
            "locale": ""
        }),
        "code": "",
        "expiration": "",
        "importance": "",
        "deliveryMode": "",
        "listenFor": (),
        "textHighlights": (
            json!({
                "text": "",
                "occurrence": 0
            })
        ),
        "semanticAction": json!({
            "state": "",
            "id": "",
            "entities": json!({})
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/conversations/:conversationId/activities \
  --header 'content-type: application/json' \
  --data '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}'
echo '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}' |  \
  http POST {{baseUrl}}/v3/conversations/:conversationId/activities \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "type": "",\n  "id": "",\n  "timestamp": "",\n  "localTimestamp": "",\n  "localTimezone": "",\n  "callerId": "",\n  "serviceUrl": "",\n  "channelId": "",\n  "from": {\n    "id": "",\n    "name": "",\n    "aadObjectId": "",\n    "role": ""\n  },\n  "conversation": {\n    "isGroup": false,\n    "conversationType": "",\n    "tenantId": "",\n    "id": "",\n    "name": "",\n    "aadObjectId": "",\n    "role": ""\n  },\n  "recipient": {},\n  "textFormat": "",\n  "attachmentLayout": "",\n  "membersAdded": [\n    {}\n  ],\n  "membersRemoved": [\n    {}\n  ],\n  "reactionsAdded": [\n    {\n      "type": ""\n    }\n  ],\n  "reactionsRemoved": [\n    {}\n  ],\n  "topicName": "",\n  "historyDisclosed": false,\n  "locale": "",\n  "text": "",\n  "speak": "",\n  "inputHint": "",\n  "summary": "",\n  "suggestedActions": {\n    "to": [],\n    "actions": [\n      {\n        "type": "",\n        "title": "",\n        "image": "",\n        "imageAltText": "",\n        "text": "",\n        "displayText": "",\n        "value": {},\n        "channelData": {}\n      }\n    ]\n  },\n  "attachments": [\n    {\n      "contentType": "",\n      "contentUrl": "",\n      "content": {},\n      "name": "",\n      "thumbnailUrl": ""\n    }\n  ],\n  "entities": [\n    {\n      "type": ""\n    }\n  ],\n  "channelData": {},\n  "action": "",\n  "replyToId": "",\n  "label": "",\n  "valueType": "",\n  "value": {},\n  "name": "",\n  "relatesTo": {\n    "activityId": "",\n    "user": {},\n    "bot": {},\n    "conversation": {},\n    "channelId": "",\n    "serviceUrl": "",\n    "locale": ""\n  },\n  "code": "",\n  "expiration": "",\n  "importance": "",\n  "deliveryMode": "",\n  "listenFor": [],\n  "textHighlights": [\n    {\n      "text": "",\n      "occurrence": 0\n    }\n  ],\n  "semanticAction": {\n    "state": "",\n    "id": "",\n    "entities": {}\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v3/conversations/:conversationId/activities
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": [
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  ],
  "conversation": [
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  ],
  "recipient": [],
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [[]],
  "membersRemoved": [[]],
  "reactionsAdded": [["type": ""]],
  "reactionsRemoved": [[]],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": [
    "to": [],
    "actions": [
      [
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": [],
        "channelData": []
      ]
    ]
  ],
  "attachments": [
    [
      "contentType": "",
      "contentUrl": "",
      "content": [],
      "name": "",
      "thumbnailUrl": ""
    ]
  ],
  "entities": [["type": ""]],
  "channelData": [],
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": [],
  "name": "",
  "relatesTo": [
    "activityId": "",
    "user": [],
    "bot": [],
    "conversation": [],
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  ],
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    [
      "text": "",
      "occurrence": 0
    ]
  ],
  "semanticAction": [
    "state": "",
    "id": "",
    "entities": []
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/conversations/:conversationId/activities")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UpdateActivity
{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId
QUERY PARAMS

conversationId
activityId
BODY json

{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId");

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  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId" {:content-type :json
                                                                                                   :form-params {:type ""
                                                                                                                 :id ""
                                                                                                                 :timestamp ""
                                                                                                                 :localTimestamp ""
                                                                                                                 :localTimezone ""
                                                                                                                 :callerId ""
                                                                                                                 :serviceUrl ""
                                                                                                                 :channelId ""
                                                                                                                 :from {:id ""
                                                                                                                        :name ""
                                                                                                                        :aadObjectId ""
                                                                                                                        :role ""}
                                                                                                                 :conversation {:isGroup false
                                                                                                                                :conversationType ""
                                                                                                                                :tenantId ""
                                                                                                                                :id ""
                                                                                                                                :name ""
                                                                                                                                :aadObjectId ""
                                                                                                                                :role ""}
                                                                                                                 :recipient {}
                                                                                                                 :textFormat ""
                                                                                                                 :attachmentLayout ""
                                                                                                                 :membersAdded [{}]
                                                                                                                 :membersRemoved [{}]
                                                                                                                 :reactionsAdded [{:type ""}]
                                                                                                                 :reactionsRemoved [{}]
                                                                                                                 :topicName ""
                                                                                                                 :historyDisclosed false
                                                                                                                 :locale ""
                                                                                                                 :text ""
                                                                                                                 :speak ""
                                                                                                                 :inputHint ""
                                                                                                                 :summary ""
                                                                                                                 :suggestedActions {:to []
                                                                                                                                    :actions [{:type ""
                                                                                                                                               :title ""
                                                                                                                                               :image ""
                                                                                                                                               :imageAltText ""
                                                                                                                                               :text ""
                                                                                                                                               :displayText ""
                                                                                                                                               :value {}
                                                                                                                                               :channelData {}}]}
                                                                                                                 :attachments [{:contentType ""
                                                                                                                                :contentUrl ""
                                                                                                                                :content {}
                                                                                                                                :name ""
                                                                                                                                :thumbnailUrl ""}]
                                                                                                                 :entities [{:type ""}]
                                                                                                                 :channelData {}
                                                                                                                 :action ""
                                                                                                                 :replyToId ""
                                                                                                                 :label ""
                                                                                                                 :valueType ""
                                                                                                                 :value {}
                                                                                                                 :name ""
                                                                                                                 :relatesTo {:activityId ""
                                                                                                                             :user {}
                                                                                                                             :bot {}
                                                                                                                             :conversation {}
                                                                                                                             :channelId ""
                                                                                                                             :serviceUrl ""
                                                                                                                             :locale ""}
                                                                                                                 :code ""
                                                                                                                 :expiration ""
                                                                                                                 :importance ""
                                                                                                                 :deliveryMode ""
                                                                                                                 :listenFor []
                                                                                                                 :textHighlights [{:text ""
                                                                                                                                   :occurrence 0}]
                                                                                                                 :semanticAction {:state ""
                                                                                                                                  :id ""
                                                                                                                                  :entities {}}}})
require "http/client"

url = "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\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}}/v3/conversations/:conversationId/activities/:activityId"),
    Content = new StringContent("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"

	payload := strings.NewReader("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\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/v3/conversations/:conversationId/activities/:activityId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1745

{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId")
  .header("content-type", "application/json")
  .body("{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")
  .asString();
const data = JSON.stringify({
  type: '',
  id: '',
  timestamp: '',
  localTimestamp: '',
  localTimezone: '',
  callerId: '',
  serviceUrl: '',
  channelId: '',
  from: {
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  conversation: {
    isGroup: false,
    conversationType: '',
    tenantId: '',
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  recipient: {},
  textFormat: '',
  attachmentLayout: '',
  membersAdded: [
    {}
  ],
  membersRemoved: [
    {}
  ],
  reactionsAdded: [
    {
      type: ''
    }
  ],
  reactionsRemoved: [
    {}
  ],
  topicName: '',
  historyDisclosed: false,
  locale: '',
  text: '',
  speak: '',
  inputHint: '',
  summary: '',
  suggestedActions: {
    to: [],
    actions: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ]
  },
  attachments: [
    {
      contentType: '',
      contentUrl: '',
      content: {},
      name: '',
      thumbnailUrl: ''
    }
  ],
  entities: [
    {
      type: ''
    }
  ],
  channelData: {},
  action: '',
  replyToId: '',
  label: '',
  valueType: '',
  value: {},
  name: '',
  relatesTo: {
    activityId: '',
    user: {},
    bot: {},
    conversation: {},
    channelId: '',
    serviceUrl: '',
    locale: ''
  },
  code: '',
  expiration: '',
  importance: '',
  deliveryMode: '',
  listenFor: [],
  textHighlights: [
    {
      text: '',
      occurrence: 0
    }
  ],
  semanticAction: {
    state: '',
    id: '',
    entities: {}
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId',
  headers: {'content-type': 'application/json'},
  data: {
    type: '',
    id: '',
    timestamp: '',
    localTimestamp: '',
    localTimezone: '',
    callerId: '',
    serviceUrl: '',
    channelId: '',
    from: {id: '', name: '', aadObjectId: '', role: ''},
    conversation: {
      isGroup: false,
      conversationType: '',
      tenantId: '',
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    recipient: {},
    textFormat: '',
    attachmentLayout: '',
    membersAdded: [{}],
    membersRemoved: [{}],
    reactionsAdded: [{type: ''}],
    reactionsRemoved: [{}],
    topicName: '',
    historyDisclosed: false,
    locale: '',
    text: '',
    speak: '',
    inputHint: '',
    summary: '',
    suggestedActions: {
      to: [],
      actions: [
        {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      ]
    },
    attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
    entities: [{type: ''}],
    channelData: {},
    action: '',
    replyToId: '',
    label: '',
    valueType: '',
    value: {},
    name: '',
    relatesTo: {
      activityId: '',
      user: {},
      bot: {},
      conversation: {},
      channelId: '',
      serviceUrl: '',
      locale: ''
    },
    code: '',
    expiration: '',
    importance: '',
    deliveryMode: '',
    listenFor: [],
    textHighlights: [{text: '', occurrence: 0}],
    semanticAction: {state: '', id: '', entities: {}}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"type":"","id":"","timestamp":"","localTimestamp":"","localTimezone":"","callerId":"","serviceUrl":"","channelId":"","from":{"id":"","name":"","aadObjectId":"","role":""},"conversation":{"isGroup":false,"conversationType":"","tenantId":"","id":"","name":"","aadObjectId":"","role":""},"recipient":{},"textFormat":"","attachmentLayout":"","membersAdded":[{}],"membersRemoved":[{}],"reactionsAdded":[{"type":""}],"reactionsRemoved":[{}],"topicName":"","historyDisclosed":false,"locale":"","text":"","speak":"","inputHint":"","summary":"","suggestedActions":{"to":[],"actions":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}]},"attachments":[{"contentType":"","contentUrl":"","content":{},"name":"","thumbnailUrl":""}],"entities":[{"type":""}],"channelData":{},"action":"","replyToId":"","label":"","valueType":"","value":{},"name":"","relatesTo":{"activityId":"","user":{},"bot":{},"conversation":{},"channelId":"","serviceUrl":"","locale":""},"code":"","expiration":"","importance":"","deliveryMode":"","listenFor":[],"textHighlights":[{"text":"","occurrence":0}],"semanticAction":{"state":"","id":"","entities":{}}}'
};

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}}/v3/conversations/:conversationId/activities/:activityId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "type": "",\n  "id": "",\n  "timestamp": "",\n  "localTimestamp": "",\n  "localTimezone": "",\n  "callerId": "",\n  "serviceUrl": "",\n  "channelId": "",\n  "from": {\n    "id": "",\n    "name": "",\n    "aadObjectId": "",\n    "role": ""\n  },\n  "conversation": {\n    "isGroup": false,\n    "conversationType": "",\n    "tenantId": "",\n    "id": "",\n    "name": "",\n    "aadObjectId": "",\n    "role": ""\n  },\n  "recipient": {},\n  "textFormat": "",\n  "attachmentLayout": "",\n  "membersAdded": [\n    {}\n  ],\n  "membersRemoved": [\n    {}\n  ],\n  "reactionsAdded": [\n    {\n      "type": ""\n    }\n  ],\n  "reactionsRemoved": [\n    {}\n  ],\n  "topicName": "",\n  "historyDisclosed": false,\n  "locale": "",\n  "text": "",\n  "speak": "",\n  "inputHint": "",\n  "summary": "",\n  "suggestedActions": {\n    "to": [],\n    "actions": [\n      {\n        "type": "",\n        "title": "",\n        "image": "",\n        "imageAltText": "",\n        "text": "",\n        "displayText": "",\n        "value": {},\n        "channelData": {}\n      }\n    ]\n  },\n  "attachments": [\n    {\n      "contentType": "",\n      "contentUrl": "",\n      "content": {},\n      "name": "",\n      "thumbnailUrl": ""\n    }\n  ],\n  "entities": [\n    {\n      "type": ""\n    }\n  ],\n  "channelData": {},\n  "action": "",\n  "replyToId": "",\n  "label": "",\n  "valueType": "",\n  "value": {},\n  "name": "",\n  "relatesTo": {\n    "activityId": "",\n    "user": {},\n    "bot": {},\n    "conversation": {},\n    "channelId": "",\n    "serviceUrl": "",\n    "locale": ""\n  },\n  "code": "",\n  "expiration": "",\n  "importance": "",\n  "deliveryMode": "",\n  "listenFor": [],\n  "textHighlights": [\n    {\n      "text": "",\n      "occurrence": 0\n    }\n  ],\n  "semanticAction": {\n    "state": "",\n    "id": "",\n    "entities": {}\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId")
  .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/v3/conversations/:conversationId/activities/:activityId',
  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({
  type: '',
  id: '',
  timestamp: '',
  localTimestamp: '',
  localTimezone: '',
  callerId: '',
  serviceUrl: '',
  channelId: '',
  from: {id: '', name: '', aadObjectId: '', role: ''},
  conversation: {
    isGroup: false,
    conversationType: '',
    tenantId: '',
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  recipient: {},
  textFormat: '',
  attachmentLayout: '',
  membersAdded: [{}],
  membersRemoved: [{}],
  reactionsAdded: [{type: ''}],
  reactionsRemoved: [{}],
  topicName: '',
  historyDisclosed: false,
  locale: '',
  text: '',
  speak: '',
  inputHint: '',
  summary: '',
  suggestedActions: {
    to: [],
    actions: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ]
  },
  attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
  entities: [{type: ''}],
  channelData: {},
  action: '',
  replyToId: '',
  label: '',
  valueType: '',
  value: {},
  name: '',
  relatesTo: {
    activityId: '',
    user: {},
    bot: {},
    conversation: {},
    channelId: '',
    serviceUrl: '',
    locale: ''
  },
  code: '',
  expiration: '',
  importance: '',
  deliveryMode: '',
  listenFor: [],
  textHighlights: [{text: '', occurrence: 0}],
  semanticAction: {state: '', id: '', entities: {}}
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId',
  headers: {'content-type': 'application/json'},
  body: {
    type: '',
    id: '',
    timestamp: '',
    localTimestamp: '',
    localTimezone: '',
    callerId: '',
    serviceUrl: '',
    channelId: '',
    from: {id: '', name: '', aadObjectId: '', role: ''},
    conversation: {
      isGroup: false,
      conversationType: '',
      tenantId: '',
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    recipient: {},
    textFormat: '',
    attachmentLayout: '',
    membersAdded: [{}],
    membersRemoved: [{}],
    reactionsAdded: [{type: ''}],
    reactionsRemoved: [{}],
    topicName: '',
    historyDisclosed: false,
    locale: '',
    text: '',
    speak: '',
    inputHint: '',
    summary: '',
    suggestedActions: {
      to: [],
      actions: [
        {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      ]
    },
    attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
    entities: [{type: ''}],
    channelData: {},
    action: '',
    replyToId: '',
    label: '',
    valueType: '',
    value: {},
    name: '',
    relatesTo: {
      activityId: '',
      user: {},
      bot: {},
      conversation: {},
      channelId: '',
      serviceUrl: '',
      locale: ''
    },
    code: '',
    expiration: '',
    importance: '',
    deliveryMode: '',
    listenFor: [],
    textHighlights: [{text: '', occurrence: 0}],
    semanticAction: {state: '', id: '', entities: {}}
  },
  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}}/v3/conversations/:conversationId/activities/:activityId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  type: '',
  id: '',
  timestamp: '',
  localTimestamp: '',
  localTimezone: '',
  callerId: '',
  serviceUrl: '',
  channelId: '',
  from: {
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  conversation: {
    isGroup: false,
    conversationType: '',
    tenantId: '',
    id: '',
    name: '',
    aadObjectId: '',
    role: ''
  },
  recipient: {},
  textFormat: '',
  attachmentLayout: '',
  membersAdded: [
    {}
  ],
  membersRemoved: [
    {}
  ],
  reactionsAdded: [
    {
      type: ''
    }
  ],
  reactionsRemoved: [
    {}
  ],
  topicName: '',
  historyDisclosed: false,
  locale: '',
  text: '',
  speak: '',
  inputHint: '',
  summary: '',
  suggestedActions: {
    to: [],
    actions: [
      {
        type: '',
        title: '',
        image: '',
        imageAltText: '',
        text: '',
        displayText: '',
        value: {},
        channelData: {}
      }
    ]
  },
  attachments: [
    {
      contentType: '',
      contentUrl: '',
      content: {},
      name: '',
      thumbnailUrl: ''
    }
  ],
  entities: [
    {
      type: ''
    }
  ],
  channelData: {},
  action: '',
  replyToId: '',
  label: '',
  valueType: '',
  value: {},
  name: '',
  relatesTo: {
    activityId: '',
    user: {},
    bot: {},
    conversation: {},
    channelId: '',
    serviceUrl: '',
    locale: ''
  },
  code: '',
  expiration: '',
  importance: '',
  deliveryMode: '',
  listenFor: [],
  textHighlights: [
    {
      text: '',
      occurrence: 0
    }
  ],
  semanticAction: {
    state: '',
    id: '',
    entities: {}
  }
});

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}}/v3/conversations/:conversationId/activities/:activityId',
  headers: {'content-type': 'application/json'},
  data: {
    type: '',
    id: '',
    timestamp: '',
    localTimestamp: '',
    localTimezone: '',
    callerId: '',
    serviceUrl: '',
    channelId: '',
    from: {id: '', name: '', aadObjectId: '', role: ''},
    conversation: {
      isGroup: false,
      conversationType: '',
      tenantId: '',
      id: '',
      name: '',
      aadObjectId: '',
      role: ''
    },
    recipient: {},
    textFormat: '',
    attachmentLayout: '',
    membersAdded: [{}],
    membersRemoved: [{}],
    reactionsAdded: [{type: ''}],
    reactionsRemoved: [{}],
    topicName: '',
    historyDisclosed: false,
    locale: '',
    text: '',
    speak: '',
    inputHint: '',
    summary: '',
    suggestedActions: {
      to: [],
      actions: [
        {
          type: '',
          title: '',
          image: '',
          imageAltText: '',
          text: '',
          displayText: '',
          value: {},
          channelData: {}
        }
      ]
    },
    attachments: [{contentType: '', contentUrl: '', content: {}, name: '', thumbnailUrl: ''}],
    entities: [{type: ''}],
    channelData: {},
    action: '',
    replyToId: '',
    label: '',
    valueType: '',
    value: {},
    name: '',
    relatesTo: {
      activityId: '',
      user: {},
      bot: {},
      conversation: {},
      channelId: '',
      serviceUrl: '',
      locale: ''
    },
    code: '',
    expiration: '',
    importance: '',
    deliveryMode: '',
    listenFor: [],
    textHighlights: [{text: '', occurrence: 0}],
    semanticAction: {state: '', id: '', entities: {}}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"type":"","id":"","timestamp":"","localTimestamp":"","localTimezone":"","callerId":"","serviceUrl":"","channelId":"","from":{"id":"","name":"","aadObjectId":"","role":""},"conversation":{"isGroup":false,"conversationType":"","tenantId":"","id":"","name":"","aadObjectId":"","role":""},"recipient":{},"textFormat":"","attachmentLayout":"","membersAdded":[{}],"membersRemoved":[{}],"reactionsAdded":[{"type":""}],"reactionsRemoved":[{}],"topicName":"","historyDisclosed":false,"locale":"","text":"","speak":"","inputHint":"","summary":"","suggestedActions":{"to":[],"actions":[{"type":"","title":"","image":"","imageAltText":"","text":"","displayText":"","value":{},"channelData":{}}]},"attachments":[{"contentType":"","contentUrl":"","content":{},"name":"","thumbnailUrl":""}],"entities":[{"type":""}],"channelData":{},"action":"","replyToId":"","label":"","valueType":"","value":{},"name":"","relatesTo":{"activityId":"","user":{},"bot":{},"conversation":{},"channelId":"","serviceUrl":"","locale":""},"code":"","expiration":"","importance":"","deliveryMode":"","listenFor":[],"textHighlights":[{"text":"","occurrence":0}],"semanticAction":{"state":"","id":"","entities":{}}}'
};

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 = @{ @"type": @"",
                              @"id": @"",
                              @"timestamp": @"",
                              @"localTimestamp": @"",
                              @"localTimezone": @"",
                              @"callerId": @"",
                              @"serviceUrl": @"",
                              @"channelId": @"",
                              @"from": @{ @"id": @"", @"name": @"", @"aadObjectId": @"", @"role": @"" },
                              @"conversation": @{ @"isGroup": @NO, @"conversationType": @"", @"tenantId": @"", @"id": @"", @"name": @"", @"aadObjectId": @"", @"role": @"" },
                              @"recipient": @{  },
                              @"textFormat": @"",
                              @"attachmentLayout": @"",
                              @"membersAdded": @[ @{  } ],
                              @"membersRemoved": @[ @{  } ],
                              @"reactionsAdded": @[ @{ @"type": @"" } ],
                              @"reactionsRemoved": @[ @{  } ],
                              @"topicName": @"",
                              @"historyDisclosed": @NO,
                              @"locale": @"",
                              @"text": @"",
                              @"speak": @"",
                              @"inputHint": @"",
                              @"summary": @"",
                              @"suggestedActions": @{ @"to": @[  ], @"actions": @[ @{ @"type": @"", @"title": @"", @"image": @"", @"imageAltText": @"", @"text": @"", @"displayText": @"", @"value": @{  }, @"channelData": @{  } } ] },
                              @"attachments": @[ @{ @"contentType": @"", @"contentUrl": @"", @"content": @{  }, @"name": @"", @"thumbnailUrl": @"" } ],
                              @"entities": @[ @{ @"type": @"" } ],
                              @"channelData": @{  },
                              @"action": @"",
                              @"replyToId": @"",
                              @"label": @"",
                              @"valueType": @"",
                              @"value": @{  },
                              @"name": @"",
                              @"relatesTo": @{ @"activityId": @"", @"user": @{  }, @"bot": @{  }, @"conversation": @{  }, @"channelId": @"", @"serviceUrl": @"", @"locale": @"" },
                              @"code": @"",
                              @"expiration": @"",
                              @"importance": @"",
                              @"deliveryMode": @"",
                              @"listenFor": @[  ],
                              @"textHighlights": @[ @{ @"text": @"", @"occurrence": @0 } ],
                              @"semanticAction": @{ @"state": @"", @"id": @"", @"entities": @{  } } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"]
                                                       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}}/v3/conversations/:conversationId/activities/:activityId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId",
  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([
    'type' => '',
    'id' => '',
    'timestamp' => '',
    'localTimestamp' => '',
    'localTimezone' => '',
    'callerId' => '',
    'serviceUrl' => '',
    'channelId' => '',
    'from' => [
        'id' => '',
        'name' => '',
        'aadObjectId' => '',
        'role' => ''
    ],
    'conversation' => [
        'isGroup' => null,
        'conversationType' => '',
        'tenantId' => '',
        'id' => '',
        'name' => '',
        'aadObjectId' => '',
        'role' => ''
    ],
    'recipient' => [
        
    ],
    'textFormat' => '',
    'attachmentLayout' => '',
    'membersAdded' => [
        [
                
        ]
    ],
    'membersRemoved' => [
        [
                
        ]
    ],
    'reactionsAdded' => [
        [
                'type' => ''
        ]
    ],
    'reactionsRemoved' => [
        [
                
        ]
    ],
    'topicName' => '',
    'historyDisclosed' => null,
    'locale' => '',
    'text' => '',
    'speak' => '',
    'inputHint' => '',
    'summary' => '',
    'suggestedActions' => [
        'to' => [
                
        ],
        'actions' => [
                [
                                'type' => '',
                                'title' => '',
                                'image' => '',
                                'imageAltText' => '',
                                'text' => '',
                                'displayText' => '',
                                'value' => [
                                                                
                                ],
                                'channelData' => [
                                                                
                                ]
                ]
        ]
    ],
    'attachments' => [
        [
                'contentType' => '',
                'contentUrl' => '',
                'content' => [
                                
                ],
                'name' => '',
                'thumbnailUrl' => ''
        ]
    ],
    'entities' => [
        [
                'type' => ''
        ]
    ],
    'channelData' => [
        
    ],
    'action' => '',
    'replyToId' => '',
    'label' => '',
    'valueType' => '',
    'value' => [
        
    ],
    'name' => '',
    'relatesTo' => [
        'activityId' => '',
        'user' => [
                
        ],
        'bot' => [
                
        ],
        'conversation' => [
                
        ],
        'channelId' => '',
        'serviceUrl' => '',
        'locale' => ''
    ],
    'code' => '',
    'expiration' => '',
    'importance' => '',
    'deliveryMode' => '',
    'listenFor' => [
        
    ],
    'textHighlights' => [
        [
                'text' => '',
                'occurrence' => 0
        ]
    ],
    'semanticAction' => [
        'state' => '',
        'id' => '',
        'entities' => [
                
        ]
    ]
  ]),
  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}}/v3/conversations/:conversationId/activities/:activityId', [
  'body' => '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'type' => '',
  'id' => '',
  'timestamp' => '',
  'localTimestamp' => '',
  'localTimezone' => '',
  'callerId' => '',
  'serviceUrl' => '',
  'channelId' => '',
  'from' => [
    'id' => '',
    'name' => '',
    'aadObjectId' => '',
    'role' => ''
  ],
  'conversation' => [
    'isGroup' => null,
    'conversationType' => '',
    'tenantId' => '',
    'id' => '',
    'name' => '',
    'aadObjectId' => '',
    'role' => ''
  ],
  'recipient' => [
    
  ],
  'textFormat' => '',
  'attachmentLayout' => '',
  'membersAdded' => [
    [
        
    ]
  ],
  'membersRemoved' => [
    [
        
    ]
  ],
  'reactionsAdded' => [
    [
        'type' => ''
    ]
  ],
  'reactionsRemoved' => [
    [
        
    ]
  ],
  'topicName' => '',
  'historyDisclosed' => null,
  'locale' => '',
  'text' => '',
  'speak' => '',
  'inputHint' => '',
  'summary' => '',
  'suggestedActions' => [
    'to' => [
        
    ],
    'actions' => [
        [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ]
  ],
  'attachments' => [
    [
        'contentType' => '',
        'contentUrl' => '',
        'content' => [
                
        ],
        'name' => '',
        'thumbnailUrl' => ''
    ]
  ],
  'entities' => [
    [
        'type' => ''
    ]
  ],
  'channelData' => [
    
  ],
  'action' => '',
  'replyToId' => '',
  'label' => '',
  'valueType' => '',
  'value' => [
    
  ],
  'name' => '',
  'relatesTo' => [
    'activityId' => '',
    'user' => [
        
    ],
    'bot' => [
        
    ],
    'conversation' => [
        
    ],
    'channelId' => '',
    'serviceUrl' => '',
    'locale' => ''
  ],
  'code' => '',
  'expiration' => '',
  'importance' => '',
  'deliveryMode' => '',
  'listenFor' => [
    
  ],
  'textHighlights' => [
    [
        'text' => '',
        'occurrence' => 0
    ]
  ],
  'semanticAction' => [
    'state' => '',
    'id' => '',
    'entities' => [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'type' => '',
  'id' => '',
  'timestamp' => '',
  'localTimestamp' => '',
  'localTimezone' => '',
  'callerId' => '',
  'serviceUrl' => '',
  'channelId' => '',
  'from' => [
    'id' => '',
    'name' => '',
    'aadObjectId' => '',
    'role' => ''
  ],
  'conversation' => [
    'isGroup' => null,
    'conversationType' => '',
    'tenantId' => '',
    'id' => '',
    'name' => '',
    'aadObjectId' => '',
    'role' => ''
  ],
  'recipient' => [
    
  ],
  'textFormat' => '',
  'attachmentLayout' => '',
  'membersAdded' => [
    [
        
    ]
  ],
  'membersRemoved' => [
    [
        
    ]
  ],
  'reactionsAdded' => [
    [
        'type' => ''
    ]
  ],
  'reactionsRemoved' => [
    [
        
    ]
  ],
  'topicName' => '',
  'historyDisclosed' => null,
  'locale' => '',
  'text' => '',
  'speak' => '',
  'inputHint' => '',
  'summary' => '',
  'suggestedActions' => [
    'to' => [
        
    ],
    'actions' => [
        [
                'type' => '',
                'title' => '',
                'image' => '',
                'imageAltText' => '',
                'text' => '',
                'displayText' => '',
                'value' => [
                                
                ],
                'channelData' => [
                                
                ]
        ]
    ]
  ],
  'attachments' => [
    [
        'contentType' => '',
        'contentUrl' => '',
        'content' => [
                
        ],
        'name' => '',
        'thumbnailUrl' => ''
    ]
  ],
  'entities' => [
    [
        'type' => ''
    ]
  ],
  'channelData' => [
    
  ],
  'action' => '',
  'replyToId' => '',
  'label' => '',
  'valueType' => '',
  'value' => [
    
  ],
  'name' => '',
  'relatesTo' => [
    'activityId' => '',
    'user' => [
        
    ],
    'bot' => [
        
    ],
    'conversation' => [
        
    ],
    'channelId' => '',
    'serviceUrl' => '',
    'locale' => ''
  ],
  'code' => '',
  'expiration' => '',
  'importance' => '',
  'deliveryMode' => '',
  'listenFor' => [
    
  ],
  'textHighlights' => [
    [
        'text' => '',
        'occurrence' => 0
    ]
  ],
  'semanticAction' => [
    'state' => '',
    'id' => '',
    'entities' => [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId');
$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}}/v3/conversations/:conversationId/activities/:activityId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/v3/conversations/:conversationId/activities/:activityId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"

payload = {
    "type": "",
    "id": "",
    "timestamp": "",
    "localTimestamp": "",
    "localTimezone": "",
    "callerId": "",
    "serviceUrl": "",
    "channelId": "",
    "from": {
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
    },
    "conversation": {
        "isGroup": False,
        "conversationType": "",
        "tenantId": "",
        "id": "",
        "name": "",
        "aadObjectId": "",
        "role": ""
    },
    "recipient": {},
    "textFormat": "",
    "attachmentLayout": "",
    "membersAdded": [{}],
    "membersRemoved": [{}],
    "reactionsAdded": [{ "type": "" }],
    "reactionsRemoved": [{}],
    "topicName": "",
    "historyDisclosed": False,
    "locale": "",
    "text": "",
    "speak": "",
    "inputHint": "",
    "summary": "",
    "suggestedActions": {
        "to": [],
        "actions": [
            {
                "type": "",
                "title": "",
                "image": "",
                "imageAltText": "",
                "text": "",
                "displayText": "",
                "value": {},
                "channelData": {}
            }
        ]
    },
    "attachments": [
        {
            "contentType": "",
            "contentUrl": "",
            "content": {},
            "name": "",
            "thumbnailUrl": ""
        }
    ],
    "entities": [{ "type": "" }],
    "channelData": {},
    "action": "",
    "replyToId": "",
    "label": "",
    "valueType": "",
    "value": {},
    "name": "",
    "relatesTo": {
        "activityId": "",
        "user": {},
        "bot": {},
        "conversation": {},
        "channelId": "",
        "serviceUrl": "",
        "locale": ""
    },
    "code": "",
    "expiration": "",
    "importance": "",
    "deliveryMode": "",
    "listenFor": [],
    "textHighlights": [
        {
            "text": "",
            "occurrence": 0
        }
    ],
    "semanticAction": {
        "state": "",
        "id": "",
        "entities": {}
    }
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId"

payload <- "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\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}}/v3/conversations/:conversationId/activities/:activityId")

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  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/v3/conversations/:conversationId/activities/:activityId') do |req|
  req.body = "{\n  \"type\": \"\",\n  \"id\": \"\",\n  \"timestamp\": \"\",\n  \"localTimestamp\": \"\",\n  \"localTimezone\": \"\",\n  \"callerId\": \"\",\n  \"serviceUrl\": \"\",\n  \"channelId\": \"\",\n  \"from\": {\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"conversation\": {\n    \"isGroup\": false,\n    \"conversationType\": \"\",\n    \"tenantId\": \"\",\n    \"id\": \"\",\n    \"name\": \"\",\n    \"aadObjectId\": \"\",\n    \"role\": \"\"\n  },\n  \"recipient\": {},\n  \"textFormat\": \"\",\n  \"attachmentLayout\": \"\",\n  \"membersAdded\": [\n    {}\n  ],\n  \"membersRemoved\": [\n    {}\n  ],\n  \"reactionsAdded\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"reactionsRemoved\": [\n    {}\n  ],\n  \"topicName\": \"\",\n  \"historyDisclosed\": false,\n  \"locale\": \"\",\n  \"text\": \"\",\n  \"speak\": \"\",\n  \"inputHint\": \"\",\n  \"summary\": \"\",\n  \"suggestedActions\": {\n    \"to\": [],\n    \"actions\": [\n      {\n        \"type\": \"\",\n        \"title\": \"\",\n        \"image\": \"\",\n        \"imageAltText\": \"\",\n        \"text\": \"\",\n        \"displayText\": \"\",\n        \"value\": {},\n        \"channelData\": {}\n      }\n    ]\n  },\n  \"attachments\": [\n    {\n      \"contentType\": \"\",\n      \"contentUrl\": \"\",\n      \"content\": {},\n      \"name\": \"\",\n      \"thumbnailUrl\": \"\"\n    }\n  ],\n  \"entities\": [\n    {\n      \"type\": \"\"\n    }\n  ],\n  \"channelData\": {},\n  \"action\": \"\",\n  \"replyToId\": \"\",\n  \"label\": \"\",\n  \"valueType\": \"\",\n  \"value\": {},\n  \"name\": \"\",\n  \"relatesTo\": {\n    \"activityId\": \"\",\n    \"user\": {},\n    \"bot\": {},\n    \"conversation\": {},\n    \"channelId\": \"\",\n    \"serviceUrl\": \"\",\n    \"locale\": \"\"\n  },\n  \"code\": \"\",\n  \"expiration\": \"\",\n  \"importance\": \"\",\n  \"deliveryMode\": \"\",\n  \"listenFor\": [],\n  \"textHighlights\": [\n    {\n      \"text\": \"\",\n      \"occurrence\": 0\n    }\n  ],\n  \"semanticAction\": {\n    \"state\": \"\",\n    \"id\": \"\",\n    \"entities\": {}\n  }\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}}/v3/conversations/:conversationId/activities/:activityId";

    let payload = json!({
        "type": "",
        "id": "",
        "timestamp": "",
        "localTimestamp": "",
        "localTimezone": "",
        "callerId": "",
        "serviceUrl": "",
        "channelId": "",
        "from": json!({
            "id": "",
            "name": "",
            "aadObjectId": "",
            "role": ""
        }),
        "conversation": json!({
            "isGroup": false,
            "conversationType": "",
            "tenantId": "",
            "id": "",
            "name": "",
            "aadObjectId": "",
            "role": ""
        }),
        "recipient": json!({}),
        "textFormat": "",
        "attachmentLayout": "",
        "membersAdded": (json!({})),
        "membersRemoved": (json!({})),
        "reactionsAdded": (json!({"type": ""})),
        "reactionsRemoved": (json!({})),
        "topicName": "",
        "historyDisclosed": false,
        "locale": "",
        "text": "",
        "speak": "",
        "inputHint": "",
        "summary": "",
        "suggestedActions": json!({
            "to": (),
            "actions": (
                json!({
                    "type": "",
                    "title": "",
                    "image": "",
                    "imageAltText": "",
                    "text": "",
                    "displayText": "",
                    "value": json!({}),
                    "channelData": json!({})
                })
            )
        }),
        "attachments": (
            json!({
                "contentType": "",
                "contentUrl": "",
                "content": json!({}),
                "name": "",
                "thumbnailUrl": ""
            })
        ),
        "entities": (json!({"type": ""})),
        "channelData": json!({}),
        "action": "",
        "replyToId": "",
        "label": "",
        "valueType": "",
        "value": json!({}),
        "name": "",
        "relatesTo": json!({
            "activityId": "",
            "user": json!({}),
            "bot": json!({}),
            "conversation": json!({}),
            "channelId": "",
            "serviceUrl": "",
            "locale": ""
        }),
        "code": "",
        "expiration": "",
        "importance": "",
        "deliveryMode": "",
        "listenFor": (),
        "textHighlights": (
            json!({
                "text": "",
                "occurrence": 0
            })
        ),
        "semanticAction": json!({
            "state": "",
            "id": "",
            "entities": json!({})
        })
    });

    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}}/v3/conversations/:conversationId/activities/:activityId \
  --header 'content-type: application/json' \
  --data '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}'
echo '{
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": {
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "conversation": {
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  },
  "recipient": {},
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [
    {}
  ],
  "membersRemoved": [
    {}
  ],
  "reactionsAdded": [
    {
      "type": ""
    }
  ],
  "reactionsRemoved": [
    {}
  ],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": {
    "to": [],
    "actions": [
      {
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": {},
        "channelData": {}
      }
    ]
  },
  "attachments": [
    {
      "contentType": "",
      "contentUrl": "",
      "content": {},
      "name": "",
      "thumbnailUrl": ""
    }
  ],
  "entities": [
    {
      "type": ""
    }
  ],
  "channelData": {},
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": {},
  "name": "",
  "relatesTo": {
    "activityId": "",
    "user": {},
    "bot": {},
    "conversation": {},
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  },
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    {
      "text": "",
      "occurrence": 0
    }
  ],
  "semanticAction": {
    "state": "",
    "id": "",
    "entities": {}
  }
}' |  \
  http PUT {{baseUrl}}/v3/conversations/:conversationId/activities/:activityId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "type": "",\n  "id": "",\n  "timestamp": "",\n  "localTimestamp": "",\n  "localTimezone": "",\n  "callerId": "",\n  "serviceUrl": "",\n  "channelId": "",\n  "from": {\n    "id": "",\n    "name": "",\n    "aadObjectId": "",\n    "role": ""\n  },\n  "conversation": {\n    "isGroup": false,\n    "conversationType": "",\n    "tenantId": "",\n    "id": "",\n    "name": "",\n    "aadObjectId": "",\n    "role": ""\n  },\n  "recipient": {},\n  "textFormat": "",\n  "attachmentLayout": "",\n  "membersAdded": [\n    {}\n  ],\n  "membersRemoved": [\n    {}\n  ],\n  "reactionsAdded": [\n    {\n      "type": ""\n    }\n  ],\n  "reactionsRemoved": [\n    {}\n  ],\n  "topicName": "",\n  "historyDisclosed": false,\n  "locale": "",\n  "text": "",\n  "speak": "",\n  "inputHint": "",\n  "summary": "",\n  "suggestedActions": {\n    "to": [],\n    "actions": [\n      {\n        "type": "",\n        "title": "",\n        "image": "",\n        "imageAltText": "",\n        "text": "",\n        "displayText": "",\n        "value": {},\n        "channelData": {}\n      }\n    ]\n  },\n  "attachments": [\n    {\n      "contentType": "",\n      "contentUrl": "",\n      "content": {},\n      "name": "",\n      "thumbnailUrl": ""\n    }\n  ],\n  "entities": [\n    {\n      "type": ""\n    }\n  ],\n  "channelData": {},\n  "action": "",\n  "replyToId": "",\n  "label": "",\n  "valueType": "",\n  "value": {},\n  "name": "",\n  "relatesTo": {\n    "activityId": "",\n    "user": {},\n    "bot": {},\n    "conversation": {},\n    "channelId": "",\n    "serviceUrl": "",\n    "locale": ""\n  },\n  "code": "",\n  "expiration": "",\n  "importance": "",\n  "deliveryMode": "",\n  "listenFor": [],\n  "textHighlights": [\n    {\n      "text": "",\n      "occurrence": 0\n    }\n  ],\n  "semanticAction": {\n    "state": "",\n    "id": "",\n    "entities": {}\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v3/conversations/:conversationId/activities/:activityId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "type": "",
  "id": "",
  "timestamp": "",
  "localTimestamp": "",
  "localTimezone": "",
  "callerId": "",
  "serviceUrl": "",
  "channelId": "",
  "from": [
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  ],
  "conversation": [
    "isGroup": false,
    "conversationType": "",
    "tenantId": "",
    "id": "",
    "name": "",
    "aadObjectId": "",
    "role": ""
  ],
  "recipient": [],
  "textFormat": "",
  "attachmentLayout": "",
  "membersAdded": [[]],
  "membersRemoved": [[]],
  "reactionsAdded": [["type": ""]],
  "reactionsRemoved": [[]],
  "topicName": "",
  "historyDisclosed": false,
  "locale": "",
  "text": "",
  "speak": "",
  "inputHint": "",
  "summary": "",
  "suggestedActions": [
    "to": [],
    "actions": [
      [
        "type": "",
        "title": "",
        "image": "",
        "imageAltText": "",
        "text": "",
        "displayText": "",
        "value": [],
        "channelData": []
      ]
    ]
  ],
  "attachments": [
    [
      "contentType": "",
      "contentUrl": "",
      "content": [],
      "name": "",
      "thumbnailUrl": ""
    ]
  ],
  "entities": [["type": ""]],
  "channelData": [],
  "action": "",
  "replyToId": "",
  "label": "",
  "valueType": "",
  "value": [],
  "name": "",
  "relatesTo": [
    "activityId": "",
    "user": [],
    "bot": [],
    "conversation": [],
    "channelId": "",
    "serviceUrl": "",
    "locale": ""
  ],
  "code": "",
  "expiration": "",
  "importance": "",
  "deliveryMode": "",
  "listenFor": [],
  "textHighlights": [
    [
      "text": "",
      "occurrence": 0
    ]
  ],
  "semanticAction": [
    "state": "",
    "id": "",
    "entities": []
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/conversations/:conversationId/activities/:activityId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST UploadAttachment
{{baseUrl}}/v3/conversations/:conversationId/attachments
QUERY PARAMS

conversationId
BODY json

{
  "type": "",
  "name": "",
  "originalBase64": "",
  "thumbnailBase64": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3/conversations/:conversationId/attachments");

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  \"type\": \"\",\n  \"name\": \"\",\n  \"originalBase64\": \"\",\n  \"thumbnailBase64\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v3/conversations/:conversationId/attachments" {:content-type :json
                                                                                         :form-params {:type ""
                                                                                                       :name ""
                                                                                                       :originalBase64 ""
                                                                                                       :thumbnailBase64 ""}})
require "http/client"

url = "{{baseUrl}}/v3/conversations/:conversationId/attachments"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"type\": \"\",\n  \"name\": \"\",\n  \"originalBase64\": \"\",\n  \"thumbnailBase64\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v3/conversations/:conversationId/attachments"),
    Content = new StringContent("{\n  \"type\": \"\",\n  \"name\": \"\",\n  \"originalBase64\": \"\",\n  \"thumbnailBase64\": \"\"\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}}/v3/conversations/:conversationId/attachments");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"type\": \"\",\n  \"name\": \"\",\n  \"originalBase64\": \"\",\n  \"thumbnailBase64\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v3/conversations/:conversationId/attachments"

	payload := strings.NewReader("{\n  \"type\": \"\",\n  \"name\": \"\",\n  \"originalBase64\": \"\",\n  \"thumbnailBase64\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v3/conversations/:conversationId/attachments HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 79

{
  "type": "",
  "name": "",
  "originalBase64": "",
  "thumbnailBase64": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3/conversations/:conversationId/attachments")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"type\": \"\",\n  \"name\": \"\",\n  \"originalBase64\": \"\",\n  \"thumbnailBase64\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3/conversations/:conversationId/attachments"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"type\": \"\",\n  \"name\": \"\",\n  \"originalBase64\": \"\",\n  \"thumbnailBase64\": \"\"\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  \"type\": \"\",\n  \"name\": \"\",\n  \"originalBase64\": \"\",\n  \"thumbnailBase64\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3/conversations/:conversationId/attachments")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3/conversations/:conversationId/attachments")
  .header("content-type", "application/json")
  .body("{\n  \"type\": \"\",\n  \"name\": \"\",\n  \"originalBase64\": \"\",\n  \"thumbnailBase64\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  type: '',
  name: '',
  originalBase64: '',
  thumbnailBase64: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v3/conversations/:conversationId/attachments');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/conversations/:conversationId/attachments',
  headers: {'content-type': 'application/json'},
  data: {type: '', name: '', originalBase64: '', thumbnailBase64: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3/conversations/:conversationId/attachments';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"type":"","name":"","originalBase64":"","thumbnailBase64":""}'
};

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}}/v3/conversations/:conversationId/attachments',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "type": "",\n  "name": "",\n  "originalBase64": "",\n  "thumbnailBase64": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"type\": \"\",\n  \"name\": \"\",\n  \"originalBase64\": \"\",\n  \"thumbnailBase64\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3/conversations/:conversationId/attachments")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3/conversations/:conversationId/attachments',
  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({type: '', name: '', originalBase64: '', thumbnailBase64: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/conversations/:conversationId/attachments',
  headers: {'content-type': 'application/json'},
  body: {type: '', name: '', originalBase64: '', thumbnailBase64: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v3/conversations/:conversationId/attachments');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  type: '',
  name: '',
  originalBase64: '',
  thumbnailBase64: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3/conversations/:conversationId/attachments',
  headers: {'content-type': 'application/json'},
  data: {type: '', name: '', originalBase64: '', thumbnailBase64: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v3/conversations/:conversationId/attachments';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"type":"","name":"","originalBase64":"","thumbnailBase64":""}'
};

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 = @{ @"type": @"",
                              @"name": @"",
                              @"originalBase64": @"",
                              @"thumbnailBase64": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3/conversations/:conversationId/attachments"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v3/conversations/:conversationId/attachments" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"type\": \"\",\n  \"name\": \"\",\n  \"originalBase64\": \"\",\n  \"thumbnailBase64\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3/conversations/:conversationId/attachments",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'type' => '',
    'name' => '',
    'originalBase64' => '',
    'thumbnailBase64' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v3/conversations/:conversationId/attachments', [
  'body' => '{
  "type": "",
  "name": "",
  "originalBase64": "",
  "thumbnailBase64": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3/conversations/:conversationId/attachments');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'type' => '',
  'name' => '',
  'originalBase64' => '',
  'thumbnailBase64' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'type' => '',
  'name' => '',
  'originalBase64' => '',
  'thumbnailBase64' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v3/conversations/:conversationId/attachments');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3/conversations/:conversationId/attachments' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "type": "",
  "name": "",
  "originalBase64": "",
  "thumbnailBase64": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3/conversations/:conversationId/attachments' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "type": "",
  "name": "",
  "originalBase64": "",
  "thumbnailBase64": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"type\": \"\",\n  \"name\": \"\",\n  \"originalBase64\": \"\",\n  \"thumbnailBase64\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v3/conversations/:conversationId/attachments", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v3/conversations/:conversationId/attachments"

payload = {
    "type": "",
    "name": "",
    "originalBase64": "",
    "thumbnailBase64": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v3/conversations/:conversationId/attachments"

payload <- "{\n  \"type\": \"\",\n  \"name\": \"\",\n  \"originalBase64\": \"\",\n  \"thumbnailBase64\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v3/conversations/:conversationId/attachments")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"type\": \"\",\n  \"name\": \"\",\n  \"originalBase64\": \"\",\n  \"thumbnailBase64\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v3/conversations/:conversationId/attachments') do |req|
  req.body = "{\n  \"type\": \"\",\n  \"name\": \"\",\n  \"originalBase64\": \"\",\n  \"thumbnailBase64\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3/conversations/:conversationId/attachments";

    let payload = json!({
        "type": "",
        "name": "",
        "originalBase64": "",
        "thumbnailBase64": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v3/conversations/:conversationId/attachments \
  --header 'content-type: application/json' \
  --data '{
  "type": "",
  "name": "",
  "originalBase64": "",
  "thumbnailBase64": ""
}'
echo '{
  "type": "",
  "name": "",
  "originalBase64": "",
  "thumbnailBase64": ""
}' |  \
  http POST {{baseUrl}}/v3/conversations/:conversationId/attachments \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "type": "",\n  "name": "",\n  "originalBase64": "",\n  "thumbnailBase64": ""\n}' \
  --output-document \
  - {{baseUrl}}/v3/conversations/:conversationId/attachments
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "type": "",
  "name": "",
  "originalBase64": "",
  "thumbnailBase64": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3/conversations/:conversationId/attachments")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()