POST Agriculture- Agriculturist Certificate
{{baseUrl}}/agcer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/agcer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/agcer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/agcer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/agcer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/agcer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/agcer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/agcer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/agcer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/agcer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/agcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/agcer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/agcer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/agcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/agcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/agcer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/agcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/agcer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/agcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/agcer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/agcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/agcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/agcer/certificate"]
                                                       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}}/agcer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/agcer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/agcer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/agcer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/agcer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/agcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/agcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/agcer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/agcer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/agcer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/agcer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/agcer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/agcer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/agcer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/agcer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Application for License for Inter State Migrant Workmen
{{baseUrl}}/alimw/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/alimw/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/alimw/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/alimw/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/alimw/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/alimw/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/alimw/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/alimw/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/alimw/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/alimw/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/alimw/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/alimw/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/alimw/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/alimw/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/alimw/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/alimw/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/alimw/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/alimw/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/alimw/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/alimw/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/alimw/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/alimw/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/alimw/certificate"]
                                                       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}}/alimw/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/alimw/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/alimw/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/alimw/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/alimw/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/alimw/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/alimw/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/alimw/certificate", payload, headers)

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

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

url = "{{baseUrl}}/alimw/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/alimw/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/alimw/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/alimw/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/alimw/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/alimw/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/alimw/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Application for Registration of Contractor Migrant Workmen license
{{baseUrl}}/arcmw/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/arcmw/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/arcmw/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/arcmw/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/arcmw/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/arcmw/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/arcmw/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/arcmw/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/arcmw/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/arcmw/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/arcmw/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/arcmw/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/arcmw/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/arcmw/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/arcmw/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/arcmw/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/arcmw/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/arcmw/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/arcmw/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/arcmw/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/arcmw/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/arcmw/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/arcmw/certificate"]
                                                       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}}/arcmw/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/arcmw/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/arcmw/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/arcmw/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/arcmw/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/arcmw/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/arcmw/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/arcmw/certificate", payload, headers)

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

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

url = "{{baseUrl}}/arcmw/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/arcmw/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/arcmw/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/arcmw/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/arcmw/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/arcmw/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/arcmw/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Application for Registration of Motor Transport Worker Registration
{{baseUrl}}/armtw/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/armtw/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/armtw/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/armtw/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/armtw/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/armtw/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/armtw/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/armtw/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/armtw/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/armtw/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/armtw/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/armtw/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/armtw/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/armtw/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/armtw/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/armtw/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/armtw/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/armtw/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/armtw/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/armtw/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/armtw/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/armtw/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/armtw/certificate"]
                                                       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}}/armtw/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/armtw/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/armtw/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/armtw/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/armtw/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/armtw/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/armtw/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/armtw/certificate", payload, headers)

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

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

url = "{{baseUrl}}/armtw/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/armtw/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/armtw/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/armtw/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/armtw/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/armtw/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/armtw/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Application for Renewal of Contractor Migrant Workmen license
{{baseUrl}}/aecmw/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/aecmw/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/aecmw/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/aecmw/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/aecmw/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/aecmw/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/aecmw/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/aecmw/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/aecmw/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/aecmw/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/aecmw/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/aecmw/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/aecmw/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/aecmw/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/aecmw/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/aecmw/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/aecmw/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/aecmw/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/aecmw/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/aecmw/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/aecmw/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/aecmw/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/aecmw/certificate"]
                                                       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}}/aecmw/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/aecmw/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/aecmw/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/aecmw/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/aecmw/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/aecmw/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/aecmw/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/aecmw/certificate", payload, headers)

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

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

url = "{{baseUrl}}/aecmw/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/aecmw/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/aecmw/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/aecmw/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/aecmw/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/aecmw/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/aecmw/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Application for Renewal of Motor Transport Worker Registration
{{baseUrl}}/aemtw/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/aemtw/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/aemtw/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/aemtw/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/aemtw/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/aemtw/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/aemtw/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/aemtw/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/aemtw/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/aemtw/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/aemtw/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/aemtw/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/aemtw/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/aemtw/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/aemtw/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/aemtw/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/aemtw/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/aemtw/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/aemtw/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/aemtw/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/aemtw/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/aemtw/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/aemtw/certificate"]
                                                       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}}/aemtw/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/aemtw/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/aemtw/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/aemtw/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/aemtw/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/aemtw/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/aemtw/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/aemtw/certificate", payload, headers)

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

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

url = "{{baseUrl}}/aemtw/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/aemtw/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/aemtw/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/aemtw/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/aemtw/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/aemtw/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/aemtw/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST BPL Card
{{baseUrl}}/bpcrd/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/bpcrd/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/bpcrd/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/bpcrd/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/bpcrd/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/bpcrd/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/bpcrd/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/bpcrd/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/bpcrd/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/bpcrd/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/bpcrd/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/bpcrd/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/bpcrd/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/bpcrd/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/bpcrd/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/bpcrd/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/bpcrd/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/bpcrd/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/bpcrd/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/bpcrd/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/bpcrd/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/bpcrd/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/bpcrd/certificate"]
                                                       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}}/bpcrd/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/bpcrd/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/bpcrd/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/bpcrd/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/bpcrd/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/bpcrd/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/bpcrd/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/bpcrd/certificate", payload, headers)

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

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

url = "{{baseUrl}}/bpcrd/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/bpcrd/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/bpcrd/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/bpcrd/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/bpcrd/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/bpcrd/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/bpcrd/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Backward Area Certificate
{{baseUrl}}/bacer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/bacer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/bacer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/bacer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/bacer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/bacer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/bacer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/bacer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/bacer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/bacer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/bacer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/bacer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/bacer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/bacer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/bacer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/bacer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/bacer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/bacer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/bacer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/bacer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/bacer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/bacer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/bacer/certificate"]
                                                       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}}/bacer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/bacer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/bacer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/bacer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/bacer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/bacer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/bacer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/bacer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/bacer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/bacer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/bacer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/bacer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/bacer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/bacer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/bacer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Birth Certificate
{{baseUrl}}/btcer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/btcer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/btcer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/btcer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/btcer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/btcer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/btcer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/btcer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/btcer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/btcer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/btcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/btcer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/btcer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/btcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/btcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/btcer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/btcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/btcer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/btcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/btcer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/btcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/btcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/btcer/certificate"]
                                                       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}}/btcer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/btcer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/btcer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/btcer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/btcer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/btcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/btcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/btcer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/btcer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/btcer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/btcer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/btcer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/btcer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/btcer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/btcer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Bonafide Certificate
{{baseUrl}}/bhcer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/bhcer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/bhcer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/bhcer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/bhcer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/bhcer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/bhcer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/bhcer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/bhcer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/bhcer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/bhcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/bhcer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/bhcer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/bhcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/bhcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/bhcer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/bhcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/bhcer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/bhcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/bhcer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/bhcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/bhcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/bhcer/certificate"]
                                                       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}}/bhcer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/bhcer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/bhcer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/bhcer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/bhcer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/bhcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/bhcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/bhcer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/bhcer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/bhcer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/bhcer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/bhcer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/bhcer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/bhcer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/bhcer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Character Certificate
{{baseUrl}}/chcer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/chcer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/chcer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/chcer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/chcer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/chcer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/chcer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/chcer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/chcer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/chcer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/chcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/chcer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/chcer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/chcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/chcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/chcer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/chcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/chcer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/chcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/chcer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/chcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/chcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/chcer/certificate"]
                                                       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}}/chcer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/chcer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/chcer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/chcer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/chcer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/chcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/chcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/chcer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/chcer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/chcer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/chcer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/chcer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/chcer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/chcer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/chcer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Copy of Pariwar Register
{{baseUrl}}/coprg/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/coprg/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/coprg/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/coprg/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/coprg/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/coprg/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/coprg/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/coprg/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/coprg/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/coprg/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/coprg/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/coprg/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/coprg/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/coprg/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/coprg/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/coprg/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/coprg/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/coprg/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/coprg/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/coprg/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/coprg/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/coprg/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/coprg/certificate"]
                                                       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}}/coprg/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/coprg/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/coprg/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/coprg/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/coprg/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/coprg/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/coprg/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/coprg/certificate", payload, headers)

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

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

url = "{{baseUrl}}/coprg/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/coprg/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/coprg/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/coprg/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/coprg/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/coprg/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/coprg/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Death Certificate
{{baseUrl}}/dtcer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/dtcer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/dtcer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/dtcer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/dtcer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/dtcer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/dtcer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/dtcer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/dtcer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/dtcer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/dtcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/dtcer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/dtcer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/dtcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/dtcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/dtcer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/dtcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/dtcer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/dtcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/dtcer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/dtcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/dtcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/dtcer/certificate"]
                                                       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}}/dtcer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/dtcer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/dtcer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/dtcer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/dtcer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/dtcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/dtcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/dtcer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/dtcer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/dtcer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/dtcer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/dtcer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/dtcer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/dtcer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/dtcer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Disabled Person Identity Card- Certificate
{{baseUrl}}/dpicr/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/dpicr/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/dpicr/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/dpicr/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/dpicr/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/dpicr/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/dpicr/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/dpicr/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/dpicr/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/dpicr/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/dpicr/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/dpicr/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/dpicr/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/dpicr/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/dpicr/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/dpicr/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/dpicr/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/dpicr/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/dpicr/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/dpicr/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/dpicr/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/dpicr/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/dpicr/certificate"]
                                                       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}}/dpicr/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/dpicr/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/dpicr/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/dpicr/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/dpicr/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/dpicr/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/dpicr/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/dpicr/certificate", payload, headers)

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

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

url = "{{baseUrl}}/dpicr/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/dpicr/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/dpicr/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/dpicr/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/dpicr/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/dpicr/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/dpicr/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Dogra Class Certificate
{{baseUrl}}/dccer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/dccer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/dccer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/dccer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/dccer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/dccer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/dccer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/dccer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/dccer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/dccer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/dccer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/dccer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/dccer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/dccer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/dccer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/dccer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/dccer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/dccer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/dccer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/dccer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/dccer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/dccer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/dccer/certificate"]
                                                       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}}/dccer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/dccer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/dccer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/dccer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/dccer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/dccer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/dccer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/dccer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/dccer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/dccer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/dccer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/dccer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/dccer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/dccer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/dccer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Domicile Certificate
{{baseUrl}}/dmcer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/dmcer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/dmcer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/dmcer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/dmcer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/dmcer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/dmcer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/dmcer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/dmcer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/dmcer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/dmcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/dmcer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/dmcer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/dmcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/dmcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/dmcer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/dmcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/dmcer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/dmcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/dmcer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/dmcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/dmcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/dmcer/certificate"]
                                                       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}}/dmcer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/dmcer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/dmcer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/dmcer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/dmcer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/dmcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/dmcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/dmcer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/dmcer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/dmcer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/dmcer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/dmcer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/dmcer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/dmcer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/dmcer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Freedom Fighter Certificate
{{baseUrl}}/ffcer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ffcer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/ffcer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/ffcer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/ffcer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/ffcer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/ffcer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/ffcer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/ffcer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ffcer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ffcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/ffcer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/ffcer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ffcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ffcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/ffcer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ffcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/ffcer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ffcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/ffcer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/ffcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/ffcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ffcer/certificate"]
                                                       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}}/ffcer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ffcer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/ffcer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ffcer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/ffcer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/ffcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ffcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/ffcer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/ffcer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/ffcer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/ffcer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/ffcer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/ffcer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/ffcer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/ffcer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Income Certificate
{{baseUrl}}/incer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/incer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/incer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/incer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/incer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/incer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/incer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/incer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/incer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/incer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/incer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/incer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/incer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/incer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/incer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/incer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/incer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/incer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/incer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/incer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/incer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/incer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/incer/certificate"]
                                                       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}}/incer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/incer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/incer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/incer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/incer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/incer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/incer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/incer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/incer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/incer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/incer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/incer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/incer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/incer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/incer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Indigent (Needy Person) Certificate
{{baseUrl}}/igcer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/igcer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/igcer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/igcer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/igcer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/igcer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/igcer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/igcer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/igcer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/igcer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/igcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/igcer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/igcer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/igcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/igcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/igcer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/igcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/igcer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/igcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/igcer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/igcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/igcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/igcer/certificate"]
                                                       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}}/igcer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/igcer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/igcer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/igcer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/igcer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/igcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/igcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/igcer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/igcer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/igcer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/igcer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/igcer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/igcer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/igcer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/igcer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/lhcer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/lhcer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/lhcer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/lhcer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/lhcer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/lhcer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/lhcer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/lhcer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/lhcer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/lhcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/lhcer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/lhcer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/lhcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/lhcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/lhcer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/lhcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/lhcer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/lhcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/lhcer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/lhcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/lhcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/lhcer/certificate"]
                                                       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}}/lhcer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/lhcer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/lhcer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/lhcer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/lhcer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/lhcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/lhcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/lhcer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/lhcer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/lhcer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/lhcer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/lhcer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/lhcer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/lhcer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/lhcer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST MNREGA Job Card
{{baseUrl}}/mnrga/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/mnrga/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/mnrga/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/mnrga/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/mnrga/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/mnrga/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/mnrga/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/mnrga/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/mnrga/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/mnrga/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/mnrga/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/mnrga/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/mnrga/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/mnrga/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/mnrga/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/mnrga/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/mnrga/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/mnrga/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/mnrga/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/mnrga/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/mnrga/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/mnrga/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/mnrga/certificate"]
                                                       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}}/mnrga/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/mnrga/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/mnrga/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/mnrga/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/mnrga/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/mnrga/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/mnrga/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/mnrga/certificate", payload, headers)

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

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

url = "{{baseUrl}}/mnrga/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/mnrga/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/mnrga/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/mnrga/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/mnrga/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/mnrga/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/mnrga/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Marriage Certificate
{{baseUrl}}/rmcer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/rmcer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/rmcer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/rmcer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/rmcer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/rmcer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/rmcer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/rmcer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/rmcer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/rmcer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/rmcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/rmcer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/rmcer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/rmcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/rmcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/rmcer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/rmcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/rmcer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/rmcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/rmcer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/rmcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/rmcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/rmcer/certificate"]
                                                       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}}/rmcer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/rmcer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/rmcer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/rmcer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/rmcer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/rmcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/rmcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/rmcer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/rmcer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/rmcer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/rmcer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/rmcer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/rmcer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/rmcer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/rmcer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Minority Certificate
{{baseUrl}}/mncer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/mncer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/mncer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/mncer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/mncer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/mncer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/mncer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/mncer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/mncer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/mncer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/mncer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/mncer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/mncer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/mncer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/mncer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/mncer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/mncer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/mncer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/mncer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/mncer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/mncer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/mncer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/mncer/certificate"]
                                                       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}}/mncer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/mncer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/mncer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/mncer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/mncer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/mncer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/mncer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/mncer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/mncer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/mncer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/mncer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/mncer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/mncer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/mncer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/mncer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST OBC Certificate
{{baseUrl}}/obcer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/obcer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/obcer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/obcer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/obcer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/obcer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/obcer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/obcer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/obcer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/obcer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/obcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/obcer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/obcer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/obcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/obcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/obcer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/obcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/obcer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/obcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/obcer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/obcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/obcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/obcer/certificate"]
                                                       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}}/obcer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/obcer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/obcer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/obcer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/obcer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/obcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/obcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/obcer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/obcer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/obcer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/obcer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/obcer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/obcer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/obcer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/obcer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Registration Certificate for Contract Labour License
{{baseUrl}}/clcer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/clcer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/clcer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/clcer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/clcer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/clcer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/clcer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/clcer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/clcer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/clcer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/clcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/clcer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/clcer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/clcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/clcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/clcer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/clcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/clcer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/clcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/clcer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/clcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/clcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/clcer/certificate"]
                                                       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}}/clcer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/clcer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/clcer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/clcer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/clcer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/clcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/clcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/clcer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/clcer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/clcer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/clcer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/clcer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/clcer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/clcer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/clcer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Registration Certificate of Establishment Employing Contract Labour
{{baseUrl}}/ercer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ercer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/ercer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/ercer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/ercer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/ercer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/ercer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/ercer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/ercer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ercer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ercer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/ercer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/ercer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ercer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ercer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/ercer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ercer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/ercer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ercer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/ercer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/ercer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/ercer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ercer/certificate"]
                                                       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}}/ercer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ercer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/ercer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ercer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/ercer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/ercer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ercer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/ercer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/ercer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/ercer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/ercer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/ercer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/ercer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/ercer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/ercer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Registration Certificate of Shops And Commercial Establishment
{{baseUrl}}/srcer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/srcer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/srcer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/srcer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/srcer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/srcer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/srcer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/srcer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/srcer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/srcer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/srcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/srcer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/srcer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/srcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/srcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/srcer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/srcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/srcer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/srcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/srcer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/srcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/srcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/srcer/certificate"]
                                                       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}}/srcer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/srcer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/srcer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/srcer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/srcer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/srcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/srcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/srcer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/srcer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/srcer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/srcer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/srcer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/srcer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/srcer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/srcer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Renewal Certificate of Contract Labour License
{{baseUrl}}/cecer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/cecer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/cecer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/cecer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/cecer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/cecer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/cecer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/cecer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/cecer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/cecer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/cecer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/cecer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/cecer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/cecer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/cecer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/cecer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/cecer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/cecer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/cecer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/cecer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/cecer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/cecer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/cecer/certificate"]
                                                       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}}/cecer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/cecer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/cecer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/cecer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/cecer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/cecer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/cecer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/cecer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/cecer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/cecer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/cecer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/cecer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/cecer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/cecer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/cecer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Renewal Certificate of Shops And Commercial Establishment
{{baseUrl}}/secer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/secer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/secer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/secer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/secer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/secer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/secer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/secer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/secer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/secer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/secer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/secer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/secer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/secer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/secer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/secer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/secer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/secer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/secer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/secer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/secer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/secer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/secer/certificate"]
                                                       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}}/secer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/secer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/secer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/secer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/secer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/secer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/secer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/secer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/secer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/secer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/secer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/secer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/secer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/secer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/secer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Rural Area Certificate
{{baseUrl}}/racer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/racer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/racer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/racer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/racer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/racer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/racer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/racer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/racer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/racer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/racer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/racer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/racer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/racer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/racer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/racer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/racer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/racer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/racer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/racer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/racer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/racer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/racer/certificate"]
                                                       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}}/racer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/racer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/racer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/racer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/racer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/racer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/racer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/racer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/racer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/racer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/racer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/racer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/racer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/racer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/racer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST SC-ST Certificate
{{baseUrl}}/shcer/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/shcer/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/shcer/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/shcer/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/shcer/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/shcer/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/shcer/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/shcer/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/shcer/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/shcer/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/shcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/shcer/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/shcer/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/shcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/shcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/shcer/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/shcer/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/shcer/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/shcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/shcer/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/shcer/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/shcer/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/shcer/certificate"]
                                                       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}}/shcer/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/shcer/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/shcer/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/shcer/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/shcer/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/shcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/shcer/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/shcer/certificate", payload, headers)

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

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

url = "{{baseUrl}}/shcer/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/shcer/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/shcer/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/shcer/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/shcer/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/shcer/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/shcer/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.
POST Senior Citizen Identity Card- Certificate
{{baseUrl}}/sicrd/certificate
HEADERS

X-APISETU-APIKEY
{{apiKey}}
BODY json

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/sicrd/certificate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-apisetu-apikey: {{apiKey}}");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");

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

(client/post "{{baseUrl}}/sicrd/certificate" {:headers {:x-apisetu-apikey "{{apiKey}}"}
                                                              :content-type :json
                                                              :form-params {:certificateParameters {:UDF1 ""}
                                                                            :consentArtifact ""
                                                                            :format ""
                                                                            :txnId ""}})
require "http/client"

url = "{{baseUrl}}/sicrd/certificate"
headers = HTTP::Headers{
  "x-apisetu-apikey" => "{{apiKey}}"
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/sicrd/certificate"),
    Headers =
    {
        { "x-apisetu-apikey", "{{apiKey}}" },
    },
    Content = new StringContent("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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}}/sicrd/certificate");
var request = new RestRequest("", Method.Post);
request.AddHeader("x-apisetu-apikey", "{{apiKey}}");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/sicrd/certificate"

	payload := strings.NewReader("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")

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

	req.Header.Add("x-apisetu-apikey", "{{apiKey}}")
	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/sicrd/certificate HTTP/1.1
X-Apisetu-Apikey: {{apiKey}}
Content-Type: application/json
Host: example.com
Content-Length: 107

{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/sicrd/certificate")
  .setHeader("x-apisetu-apikey", "{{apiKey}}")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/sicrd/certificate"))
    .header("x-apisetu-apikey", "{{apiKey}}")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/sicrd/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/sicrd/certificate")
  .header("x-apisetu-apikey", "{{apiKey}}")
  .header("content-type", "application/json")
  .body("{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/sicrd/certificate');
xhr.setRequestHeader('x-apisetu-apikey', '{{apiKey}}');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/sicrd/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/sicrd/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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}}/sicrd/certificate',
  method: 'POST',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/sicrd/certificate")
  .post(body)
  .addHeader("x-apisetu-apikey", "{{apiKey}}")
  .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/sicrd/certificate',
  headers: {
    'x-apisetu-apikey': '{{apiKey}}',
    '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({certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/sicrd/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''},
  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}}/sicrd/certificate');

req.headers({
  'x-apisetu-apikey': '{{apiKey}}',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificateParameters: {
    UDF1: ''
  },
  consentArtifact: '',
  format: '',
  txnId: ''
});

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}}/sicrd/certificate',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  data: {certificateParameters: {UDF1: ''}, consentArtifact: '', format: '', txnId: ''}
};

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

const url = '{{baseUrl}}/sicrd/certificate';
const options = {
  method: 'POST',
  headers: {'x-apisetu-apikey': '{{apiKey}}', 'content-type': 'application/json'},
  body: '{"certificateParameters":{"UDF1":""},"consentArtifact":"","format":"","txnId":""}'
};

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

NSDictionary *headers = @{ @"x-apisetu-apikey": @"{{apiKey}}",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificateParameters": @{ @"UDF1": @"" },
                              @"consentArtifact": @"",
                              @"format": @"",
                              @"txnId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/sicrd/certificate"]
                                                       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}}/sicrd/certificate" in
let headers = Header.add_list (Header.init ()) [
  ("x-apisetu-apikey", "{{apiKey}}");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/sicrd/certificate",
  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([
    'certificateParameters' => [
        'UDF1' => ''
    ],
    'consentArtifact' => '',
    'format' => '',
    'txnId' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "x-apisetu-apikey: {{apiKey}}"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/sicrd/certificate', [
  'body' => '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'x-apisetu-apikey' => '{{apiKey}}',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/sicrd/certificate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificateParameters' => [
    'UDF1' => ''
  ],
  'consentArtifact' => '',
  'format' => '',
  'txnId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/sicrd/certificate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'x-apisetu-apikey' => '{{apiKey}}',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/sicrd/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
$headers=@{}
$headers.Add("x-apisetu-apikey", "{{apiKey}}")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/sicrd/certificate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
import http.client

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

payload = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

headers = {
    'x-apisetu-apikey': "{{apiKey}}",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/sicrd/certificate", payload, headers)

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

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

url = "{{baseUrl}}/sicrd/certificate"

payload = {
    "certificateParameters": { "UDF1": "" },
    "consentArtifact": "",
    "format": "",
    "txnId": ""
}
headers = {
    "x-apisetu-apikey": "{{apiKey}}",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/sicrd/certificate"

payload <- "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('x-apisetu-apikey' = '{{apiKey}}'), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/sicrd/certificate")

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

request = Net::HTTP::Post.new(url)
request["x-apisetu-apikey"] = '{{apiKey}}'
request["content-type"] = 'application/json'
request.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\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/sicrd/certificate') do |req|
  req.headers['x-apisetu-apikey'] = '{{apiKey}}'
  req.body = "{\n  \"certificateParameters\": {\n    \"UDF1\": \"\"\n  },\n  \"consentArtifact\": \"\",\n  \"format\": \"\",\n  \"txnId\": \"\"\n}"
end

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

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

    let payload = json!({
        "certificateParameters": json!({"UDF1": ""}),
        "consentArtifact": "",
        "format": "",
        "txnId": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-apisetu-apikey", "{{apiKey}}".parse().unwrap());
    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}}/sicrd/certificate \
  --header 'content-type: application/json' \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --data '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}'
echo '{
  "certificateParameters": {
    "UDF1": ""
  },
  "consentArtifact": "",
  "format": "",
  "txnId": ""
}' |  \
  http POST {{baseUrl}}/sicrd/certificate \
  content-type:application/json \
  x-apisetu-apikey:'{{apiKey}}'
wget --quiet \
  --method POST \
  --header 'x-apisetu-apikey: {{apiKey}}' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificateParameters": {\n    "UDF1": ""\n  },\n  "consentArtifact": "",\n  "format": "",\n  "txnId": ""\n}' \
  --output-document \
  - {{baseUrl}}/sicrd/certificate
import Foundation

let headers = [
  "x-apisetu-apikey": "{{apiKey}}",
  "content-type": "application/json"
]
let parameters = [
  "certificateParameters": ["UDF1": ""],
  "consentArtifact": "",
  "format": "",
  "txnId": ""
] as [String : Any]

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

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

Content-Type
application/pdf
RESPONSE BODY text

Response body contains contents of the certificate in PDF format.