GET Fetch Administrative Regions using Lat-Lng
{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude
HEADERS

X-RapidAPI-Key
X-RapidAPI-Host
QUERY PARAMS

latitude
longitude
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-rapidapi-key: ");
headers = curl_slist_append(headers, "x-rapidapi-host: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude" {:headers {:x-rapidapi-key ""
                                                                                                          :x-rapidapi-host ""}})
require "http/client"

url = "{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude"
headers = HTTP::Headers{
  "x-rapidapi-key" => ""
  "x-rapidapi-host" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude"),
    Headers =
    {
        { "x-rapidapi-key", "" },
        { "x-rapidapi-host", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-rapidapi-key", "");
request.AddHeader("x-rapidapi-host", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude"

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

	req.Header.Add("x-rapidapi-key", "")
	req.Header.Add("x-rapidapi-host", "")

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

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

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

}
GET /baseUrl/geometries/regions/intersecting/:latitude/:longitude HTTP/1.1
X-Rapidapi-Key: 
X-Rapidapi-Host: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude")
  .setHeader("x-rapidapi-key", "")
  .setHeader("x-rapidapi-host", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude"))
    .header("x-rapidapi-key", "")
    .header("x-rapidapi-host", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude")
  .get()
  .addHeader("x-rapidapi-key", "")
  .addHeader("x-rapidapi-host", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude")
  .header("x-rapidapi-key", "")
  .header("x-rapidapi-host", "")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude');
xhr.setRequestHeader('x-rapidapi-key', '');
xhr.setRequestHeader('x-rapidapi-host', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude',
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude';
const options = {method: 'GET', headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}};

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}}/geometries/regions/intersecting/:latitude/:longitude',
  method: 'GET',
  headers: {
    'x-rapidapi-key': '',
    'x-rapidapi-host': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude")
  .get()
  .addHeader("x-rapidapi-key", "")
  .addHeader("x-rapidapi-host", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/geometries/regions/intersecting/:latitude/:longitude',
  headers: {
    'x-rapidapi-key': '',
    'x-rapidapi-host': ''
  }
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude',
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude');

req.headers({
  'x-rapidapi-key': '',
  'x-rapidapi-host': ''
});

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude',
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

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

const url = '{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude';
const options = {method: 'GET', headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}};

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

NSDictionary *headers = @{ @"x-rapidapi-key": @"",
                           @"x-rapidapi-host": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/geometries/regions/intersecting/:latitude/:longitude" in
let headers = Header.add_list (Header.init ()) [
  ("x-rapidapi-key", "");
  ("x-rapidapi-host", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-rapidapi-host: ",
    "x-rapidapi-key: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude', [
  'headers' => [
    'x-rapidapi-host' => '',
    'x-rapidapi-key' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'x-rapidapi-key' => '',
  'x-rapidapi-host' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-rapidapi-key' => '',
  'x-rapidapi-host' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-rapidapi-key", "")
$headers.Add("x-rapidapi-host", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-rapidapi-key", "")
$headers.Add("x-rapidapi-host", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude' -Method GET -Headers $headers
import http.client

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

headers = {
    'x-rapidapi-key': "",
    'x-rapidapi-host': ""
}

conn.request("GET", "/baseUrl/geometries/regions/intersecting/:latitude/:longitude", headers=headers)

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

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

url = "{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude"

headers = {
    "x-rapidapi-key": "",
    "x-rapidapi-host": ""
}

response = requests.get(url, headers=headers)

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

url <- "{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude"

response <- VERB("GET", url, add_headers('x-rapidapi-key' = '', 'x-rapidapi-host' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude")

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

request = Net::HTTP::Get.new(url)
request["x-rapidapi-key"] = ''
request["x-rapidapi-host"] = ''

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

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

response = conn.get('/baseUrl/geometries/regions/intersecting/:latitude/:longitude') do |req|
  req.headers['x-rapidapi-key'] = ''
  req.headers['x-rapidapi-host'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-rapidapi-key", "".parse().unwrap());
    headers.insert("x-rapidapi-host", "".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude \
  --header 'x-rapidapi-host: ' \
  --header 'x-rapidapi-key: '
http GET {{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude \
  x-rapidapi-host:'' \
  x-rapidapi-key:''
wget --quiet \
  --method GET \
  --header 'x-rapidapi-key: ' \
  --header 'x-rapidapi-host: ' \
  --output-document \
  - {{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude
import Foundation

let headers = [
  "x-rapidapi-key": "",
  "x-rapidapi-host": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/geometries/regions/intersecting/:latitude/:longitude")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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

dataTask.resume()
GET Fetch Geometries
{{baseUrl}}/geometries/geometry
HEADERS

X-RapidAPI-Key
X-RapidAPI-Host
QUERY PARAMS

location[]
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/geometries/geometry?location%5B%5D=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-rapidapi-key: ");
headers = curl_slist_append(headers, "x-rapidapi-host: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/geometries/geometry" {:headers {:x-rapidapi-key ""
                                                                         :x-rapidapi-host ""}
                                                               :query-params {:location[] ""}})
require "http/client"

url = "{{baseUrl}}/geometries/geometry?location%5B%5D="
headers = HTTP::Headers{
  "x-rapidapi-key" => ""
  "x-rapidapi-host" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/geometries/geometry?location%5B%5D="),
    Headers =
    {
        { "x-rapidapi-key", "" },
        { "x-rapidapi-host", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/geometries/geometry?location%5B%5D=");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-rapidapi-key", "");
request.AddHeader("x-rapidapi-host", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/geometries/geometry?location%5B%5D="

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

	req.Header.Add("x-rapidapi-key", "")
	req.Header.Add("x-rapidapi-host", "")

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

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

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

}
GET /baseUrl/geometries/geometry?location%5B%5D= HTTP/1.1
X-Rapidapi-Key: 
X-Rapidapi-Host: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/geometries/geometry?location%5B%5D=")
  .setHeader("x-rapidapi-key", "")
  .setHeader("x-rapidapi-host", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/geometries/geometry?location%5B%5D="))
    .header("x-rapidapi-key", "")
    .header("x-rapidapi-host", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/geometries/geometry?location%5B%5D=")
  .get()
  .addHeader("x-rapidapi-key", "")
  .addHeader("x-rapidapi-host", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/geometries/geometry?location%5B%5D=")
  .header("x-rapidapi-key", "")
  .header("x-rapidapi-host", "")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/geometries/geometry?location%5B%5D=');
xhr.setRequestHeader('x-rapidapi-key', '');
xhr.setRequestHeader('x-rapidapi-host', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/geometries/geometry',
  params: {'location[]': ''},
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/geometries/geometry?location%5B%5D=';
const options = {method: 'GET', headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}};

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}}/geometries/geometry?location%5B%5D=',
  method: 'GET',
  headers: {
    'x-rapidapi-key': '',
    'x-rapidapi-host': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/geometries/geometry?location%5B%5D=")
  .get()
  .addHeader("x-rapidapi-key", "")
  .addHeader("x-rapidapi-host", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/geometries/geometry?location%5B%5D=',
  headers: {
    'x-rapidapi-key': '',
    'x-rapidapi-host': ''
  }
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/geometries/geometry',
  qs: {'location[]': ''},
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/geometries/geometry');

req.query({
  'location[]': ''
});

req.headers({
  'x-rapidapi-key': '',
  'x-rapidapi-host': ''
});

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/geometries/geometry',
  params: {'location[]': ''},
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

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

const url = '{{baseUrl}}/geometries/geometry?location%5B%5D=';
const options = {method: 'GET', headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}};

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

NSDictionary *headers = @{ @"x-rapidapi-key": @"",
                           @"x-rapidapi-host": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/geometries/geometry?location%5B%5D="]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/geometries/geometry?location%5B%5D=" in
let headers = Header.add_list (Header.init ()) [
  ("x-rapidapi-key", "");
  ("x-rapidapi-host", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/geometries/geometry?location%5B%5D=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-rapidapi-host: ",
    "x-rapidapi-key: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/geometries/geometry?location%5B%5D=', [
  'headers' => [
    'x-rapidapi-host' => '',
    'x-rapidapi-key' => '',
  ],
]);

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

$request->setQueryData([
  'location[]' => ''
]);

$request->setHeaders([
  'x-rapidapi-key' => '',
  'x-rapidapi-host' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/geometries/geometry');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'location[]' => ''
]));

$request->setHeaders([
  'x-rapidapi-key' => '',
  'x-rapidapi-host' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-rapidapi-key", "")
$headers.Add("x-rapidapi-host", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/geometries/geometry?location%5B%5D=' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-rapidapi-key", "")
$headers.Add("x-rapidapi-host", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/geometries/geometry?location%5B%5D=' -Method GET -Headers $headers
import http.client

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

headers = {
    'x-rapidapi-key': "",
    'x-rapidapi-host': ""
}

conn.request("GET", "/baseUrl/geometries/geometry?location%5B%5D=", headers=headers)

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

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

url = "{{baseUrl}}/geometries/geometry"

querystring = {"location[]":""}

headers = {
    "x-rapidapi-key": "",
    "x-rapidapi-host": ""
}

response = requests.get(url, headers=headers, params=querystring)

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

url <- "{{baseUrl}}/geometries/geometry"

queryString <- list(location[] = "")

response <- VERB("GET", url, query = queryString, add_headers('x-rapidapi-key' = '', 'x-rapidapi-host' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/geometries/geometry?location%5B%5D=")

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

request = Net::HTTP::Get.new(url)
request["x-rapidapi-key"] = ''
request["x-rapidapi-host"] = ''

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

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

response = conn.get('/baseUrl/geometries/geometry') do |req|
  req.headers['x-rapidapi-key'] = ''
  req.headers['x-rapidapi-host'] = ''
  req.params['location[]'] = ''
end

puts response.status
puts response.body
use reqwest;

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

    let querystring = [
        ("location[]", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-rapidapi-key", "".parse().unwrap());
    headers.insert("x-rapidapi-host", "".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url '{{baseUrl}}/geometries/geometry?location%5B%5D=' \
  --header 'x-rapidapi-host: ' \
  --header 'x-rapidapi-key: '
http GET '{{baseUrl}}/geometries/geometry?location%5B%5D=' \
  x-rapidapi-host:'' \
  x-rapidapi-key:''
wget --quiet \
  --method GET \
  --header 'x-rapidapi-key: ' \
  --header 'x-rapidapi-host: ' \
  --output-document \
  - '{{baseUrl}}/geometries/geometry?location%5B%5D='
import Foundation

let headers = [
  "x-rapidapi-key": "",
  "x-rapidapi-host": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/geometries/geometry?location%5B%5D=")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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

dataTask.resume()
GET Fetch Available Insights
{{baseUrl}}/data/insights
HEADERS

X-RapidAPI-Key
X-RapidAPI-Host
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/data/insights");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-rapidapi-key: ");
headers = curl_slist_append(headers, "x-rapidapi-host: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/data/insights" {:headers {:x-rapidapi-key ""
                                                                   :x-rapidapi-host ""}})
require "http/client"

url = "{{baseUrl}}/data/insights"
headers = HTTP::Headers{
  "x-rapidapi-key" => ""
  "x-rapidapi-host" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/data/insights"),
    Headers =
    {
        { "x-rapidapi-key", "" },
        { "x-rapidapi-host", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/data/insights");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-rapidapi-key", "");
request.AddHeader("x-rapidapi-host", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/data/insights"

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

	req.Header.Add("x-rapidapi-key", "")
	req.Header.Add("x-rapidapi-host", "")

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

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

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

}
GET /baseUrl/data/insights HTTP/1.1
X-Rapidapi-Key: 
X-Rapidapi-Host: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/data/insights")
  .setHeader("x-rapidapi-key", "")
  .setHeader("x-rapidapi-host", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/data/insights"))
    .header("x-rapidapi-key", "")
    .header("x-rapidapi-host", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/data/insights")
  .get()
  .addHeader("x-rapidapi-key", "")
  .addHeader("x-rapidapi-host", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/data/insights")
  .header("x-rapidapi-key", "")
  .header("x-rapidapi-host", "")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/data/insights');
xhr.setRequestHeader('x-rapidapi-key', '');
xhr.setRequestHeader('x-rapidapi-host', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/data/insights',
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/data/insights';
const options = {method: 'GET', headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}};

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}}/data/insights',
  method: 'GET',
  headers: {
    'x-rapidapi-key': '',
    'x-rapidapi-host': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/data/insights")
  .get()
  .addHeader("x-rapidapi-key", "")
  .addHeader("x-rapidapi-host", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/data/insights',
  headers: {
    'x-rapidapi-key': '',
    'x-rapidapi-host': ''
  }
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/data/insights',
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/data/insights');

req.headers({
  'x-rapidapi-key': '',
  'x-rapidapi-host': ''
});

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/data/insights',
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

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

const url = '{{baseUrl}}/data/insights';
const options = {method: 'GET', headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}};

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

NSDictionary *headers = @{ @"x-rapidapi-key": @"",
                           @"x-rapidapi-host": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/data/insights"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/data/insights" in
let headers = Header.add_list (Header.init ()) [
  ("x-rapidapi-key", "");
  ("x-rapidapi-host", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/data/insights",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-rapidapi-host: ",
    "x-rapidapi-key: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/data/insights', [
  'headers' => [
    'x-rapidapi-host' => '',
    'x-rapidapi-key' => '',
  ],
]);

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

$request->setHeaders([
  'x-rapidapi-key' => '',
  'x-rapidapi-host' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/data/insights');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-rapidapi-key' => '',
  'x-rapidapi-host' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-rapidapi-key", "")
$headers.Add("x-rapidapi-host", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/data/insights' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-rapidapi-key", "")
$headers.Add("x-rapidapi-host", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/data/insights' -Method GET -Headers $headers
import http.client

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

headers = {
    'x-rapidapi-key': "",
    'x-rapidapi-host': ""
}

conn.request("GET", "/baseUrl/data/insights", headers=headers)

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

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

url = "{{baseUrl}}/data/insights"

headers = {
    "x-rapidapi-key": "",
    "x-rapidapi-host": ""
}

response = requests.get(url, headers=headers)

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

url <- "{{baseUrl}}/data/insights"

response <- VERB("GET", url, add_headers('x-rapidapi-key' = '', 'x-rapidapi-host' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/data/insights")

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

request = Net::HTTP::Get.new(url)
request["x-rapidapi-key"] = ''
request["x-rapidapi-host"] = ''

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

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

response = conn.get('/baseUrl/data/insights') do |req|
  req.headers['x-rapidapi-key'] = ''
  req.headers['x-rapidapi-host'] = ''
end

puts response.status
puts response.body
use reqwest;

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-rapidapi-key", "".parse().unwrap());
    headers.insert("x-rapidapi-host", "".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/data/insights \
  --header 'x-rapidapi-host: ' \
  --header 'x-rapidapi-key: '
http GET {{baseUrl}}/data/insights \
  x-rapidapi-host:'' \
  x-rapidapi-key:''
wget --quiet \
  --method GET \
  --header 'x-rapidapi-key: ' \
  --header 'x-rapidapi-host: ' \
  --output-document \
  - {{baseUrl}}/data/insights
import Foundation

let headers = [
  "x-rapidapi-key": "",
  "x-rapidapi-host": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/data/insights")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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/json; charset=utf-8
RESPONSE BODY json

{
  "data": [
    {
      "description": "Median age and age brackets by gender.",
      "id": "age",
      "name": "Age",
      "version": "v2"
    },
    {
      "description": "Historical and projected population by age bracket",
      "id": "age-trends",
      "name": "Age Over Time",
      "version": "v2"
    },
    {
      "description": "Ancestry",
      "id": "ancestry",
      "name": "Ancestry",
      "version": "v2"
    },
    {
      "description": "Average home value over time.",
      "id": "avg-home-value",
      "name": "Home Value Trends",
      "version": "v1"
    },
    {
      "description": "Crime indicies across several categories",
      "id": "crime",
      "name": "Crime",
      "version": "v1"
    },
    {
      "description": "Conventionally, daytime population is equated to the number of the employees in an area. However, that number does not capture stay-at-home parents, students, and retired or unemployed individuals. This insight provides that detail.",
      "id": "daytime-population",
      "name": "Daytime Population",
      "version": "v2"
    },
    {
      "description": "Current year education levels.",
      "id": "education",
      "name": "Education (Age 25+)",
      "version": "v2"
    },
    {
      "description": "Number of employees by business category",
      "id": "employee-categories",
      "name": "Employee Categories",
      "version": "v2"
    },
    {
      "description": "Quarterly historical total number of employees (often referred to as daytime population).",
      "id": "employees",
      "name": "Daytime Population",
      "version": "v4"
    },
    {
      "description": "Number of businesses by category",
      "id": "establishment-categories",
      "name": "Establishment Categories",
      "version": "v2"
    },
    {
      "description": "Quarterly historical total number of establishments.",
      "id": "establishments",
      "name": "Business Counts",
      "version": "v4"
    },
    {
      "description": "Current year ethnicity proportions.",
      "id": "ethnicity",
      "name": "Ethnicity",
      "version": "v2"
    },
    {
      "description": "Quarterly historical gross domestic product estimates.",
      "id": "gdp",
      "name": "Gross Domestic Product",
      "version": "v3"
    },
    {
      "description": "Current year gender populations.",
      "id": "gender",
      "name": "Gender",
      "version": "v2"
    },
    {
      "description": "Age generations",
      "id": "generations",
      "name": "Generations",
      "version": "v2"
    },
    {
      "description": "Median home value and home value buckets",
      "id": "home-value",
      "name": "Home Value",
      "version": "v2"
    },
    {
      "description": "The total amount all members of a household earn.",
      "id": "household-income",
      "name": "Household Income",
      "version": "v2"
    },
    {
      "description": "Number of people per households",
      "id": "household-size",
      "name": "Household Size",
      "version": "v2"
    },
    {
      "description": "Historical counts and forecasts of number of households in an area.",
      "id": "households",
      "name": "Households",
      "version": "v3"
    },
    {
      "description": "Home renters, owners, and vacancies.",
      "id": "housing-ownership",
      "name": "Housing Ownership",
      "version": "v2"
    },
    {
      "description": "Language",
      "id": "language",
      "name": "Language",
      "version": "v2"
    },
    {
      "description": "Common market overview metrics.",
      "id": "market-context",
      "name": "Market Context",
      "version": "v1"
    },
    {
      "description": "Market gaps by category",
      "id": "market-gap",
      "name": "Market Gap",
      "version": "v1"
    },
    {
      "description": "Number of mortgages and their risks on a 1 to 5 scale.",
      "id": "mortgage-risk",
      "name": "Mortgage Risk",
      "version": "v2"
    },
    {
      "description": "Describes the occupations of residents in the trade area.",
      "id": "occupation",
      "name": "Occupation",
      "version": "v2"
    },
    {
      "description": "Historical, current and forecasted number of people living in houses and apartments within a trade area.",
      "id": "residential-population",
      "name": "Residential Population",
      "version": "v3"
    },
    {
      "description": "Salary/Wage per Employee per Annum",
      "id": "salaries",
      "name": "Salaries",
      "version": "v2"
    },
    {
      "description": "Population residing in a housing unit specifically designated as seasonal housing, like a summer cottage or winter chalet.",
      "id": "seasonal-population",
      "name": "Seasonal Population",
      "version": "v3"
    },
    {
      "description": "Expressed interest on social media within the location's trade area by business category.",
      "id": "social",
      "name": "Social Media Interest",
      "version": "v3"
    },
    {
      "description": "Weekly expenditures per product.",
      "id": "spending",
      "name": "Spending",
      "version": "v2"
    },
    {
      "description": "Population residing in a hotel or RV (Recreational Vehicle) for at least 1 night.",
      "id": "transient-population",
      "name": "Transient Population",
      "version": "v3"
    },
    {
      "description": "Number of vehicles available per household",
      "id": "vehicles-per-hh",
      "name": "Vehicles per Household",
      "version": "v2"
    },
    {
      "description": "Yearly age counts up to 21 by gender",
      "id": "youth-age",
      "name": "Youth Age",
      "version": "v2"
    },
    {
      "description": "Search engine searches within a location's trade area by business category.",
      "id": "search",
      "name": "Search Engine Demand",
      "version": "v3"
    }
  ]
}
GET Fetch Insight Query Parameters
{{baseUrl}}/data/insights/:insight_id:
HEADERS

X-RapidAPI-Key
X-RapidAPI-Host
QUERY PARAMS

insight_id
:
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/data/insights/:insight_id:");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-rapidapi-key: ");
headers = curl_slist_append(headers, "x-rapidapi-host: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/data/insights/:insight_id:" {:headers {:x-rapidapi-key ""
                                                                                :x-rapidapi-host ""}})
require "http/client"

url = "{{baseUrl}}/data/insights/:insight_id:"
headers = HTTP::Headers{
  "x-rapidapi-key" => ""
  "x-rapidapi-host" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/data/insights/:insight_id:"),
    Headers =
    {
        { "x-rapidapi-key", "" },
        { "x-rapidapi-host", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/data/insights/:insight_id:");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-rapidapi-key", "");
request.AddHeader("x-rapidapi-host", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/data/insights/:insight_id:"

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

	req.Header.Add("x-rapidapi-key", "")
	req.Header.Add("x-rapidapi-host", "")

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

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

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

}
GET /baseUrl/data/insights/:insight_id: HTTP/1.1
X-Rapidapi-Key: 
X-Rapidapi-Host: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/data/insights/:insight_id:")
  .setHeader("x-rapidapi-key", "")
  .setHeader("x-rapidapi-host", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/data/insights/:insight_id:"))
    .header("x-rapidapi-key", "")
    .header("x-rapidapi-host", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/data/insights/:insight_id:")
  .get()
  .addHeader("x-rapidapi-key", "")
  .addHeader("x-rapidapi-host", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/data/insights/:insight_id:")
  .header("x-rapidapi-key", "")
  .header("x-rapidapi-host", "")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/data/insights/:insight_id:');
xhr.setRequestHeader('x-rapidapi-key', '');
xhr.setRequestHeader('x-rapidapi-host', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/data/insights/:insight_id:',
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/data/insights/:insight_id:';
const options = {method: 'GET', headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}};

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}}/data/insights/:insight_id:',
  method: 'GET',
  headers: {
    'x-rapidapi-key': '',
    'x-rapidapi-host': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/data/insights/:insight_id:")
  .get()
  .addHeader("x-rapidapi-key", "")
  .addHeader("x-rapidapi-host", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/data/insights/:insight_id:',
  headers: {
    'x-rapidapi-key': '',
    'x-rapidapi-host': ''
  }
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/data/insights/:insight_id:',
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/data/insights/:insight_id:');

req.headers({
  'x-rapidapi-key': '',
  'x-rapidapi-host': ''
});

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/data/insights/:insight_id:',
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

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

const url = '{{baseUrl}}/data/insights/:insight_id:';
const options = {method: 'GET', headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}};

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

NSDictionary *headers = @{ @"x-rapidapi-key": @"",
                           @"x-rapidapi-host": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/data/insights/:insight_id:"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/data/insights/:insight_id:" in
let headers = Header.add_list (Header.init ()) [
  ("x-rapidapi-key", "");
  ("x-rapidapi-host", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/data/insights/:insight_id:",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-rapidapi-host: ",
    "x-rapidapi-key: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/data/insights/:insight_id:', [
  'headers' => [
    'x-rapidapi-host' => '',
    'x-rapidapi-key' => '',
  ],
]);

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

$request->setHeaders([
  'x-rapidapi-key' => '',
  'x-rapidapi-host' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/data/insights/:insight_id:');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-rapidapi-key' => '',
  'x-rapidapi-host' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-rapidapi-key", "")
$headers.Add("x-rapidapi-host", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/data/insights/:insight_id:' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-rapidapi-key", "")
$headers.Add("x-rapidapi-host", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/data/insights/:insight_id:' -Method GET -Headers $headers
import http.client

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

headers = {
    'x-rapidapi-key': "",
    'x-rapidapi-host': ""
}

conn.request("GET", "/baseUrl/data/insights/:insight_id:", headers=headers)

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

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

url = "{{baseUrl}}/data/insights/:insight_id:"

headers = {
    "x-rapidapi-key": "",
    "x-rapidapi-host": ""
}

response = requests.get(url, headers=headers)

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

url <- "{{baseUrl}}/data/insights/:insight_id:"

response <- VERB("GET", url, add_headers('x-rapidapi-key' = '', 'x-rapidapi-host' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/data/insights/:insight_id:")

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

request = Net::HTTP::Get.new(url)
request["x-rapidapi-key"] = ''
request["x-rapidapi-host"] = ''

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

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

response = conn.get('/baseUrl/data/insights/:insight_id:') do |req|
  req.headers['x-rapidapi-key'] = ''
  req.headers['x-rapidapi-host'] = ''
end

puts response.status
puts response.body
use reqwest;

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-rapidapi-key", "".parse().unwrap());
    headers.insert("x-rapidapi-host", "".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/data/insights/:insight_id: \
  --header 'x-rapidapi-host: ' \
  --header 'x-rapidapi-key: '
http GET {{baseUrl}}/data/insights/:insight_id: \
  x-rapidapi-host:'' \
  x-rapidapi-key:''
wget --quiet \
  --method GET \
  --header 'x-rapidapi-key: ' \
  --header 'x-rapidapi-host: ' \
  --output-document \
  - {{baseUrl}}/data/insights/:insight_id:
import Foundation

let headers = [
  "x-rapidapi-key": "",
  "x-rapidapi-host": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/data/insights/:insight_id:")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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/json; charset=utf-8
RESPONSE BODY json

{
  "data": {
    "description": "Describes the occupations of residents in the trade area.",
    "groups": [
      "White Collar",
      "Management occupations",
      "Top executives",
      "Advertising, marketing, promotions, public relations, and sales managers",
      "Operations specialties managers",
      "Other management occupations",
      "Business and financial operations occupations",
      "Business operations specialists",
      "Financial specialists",
      "Computer and mathematical science occupations",
      "Computer specialists",
      "Mathematical science occupations",
      "Architecture and engineering occupations",
      "Architects, surveyors, and cartographers",
      "Engineers",
      "Drafters, engineering, and mapping technicians",
      "Life, physical, and social science occupations",
      "Life scientists",
      "Physical scientists",
      "Social scientists and related occupations",
      "Life, physical, and social science technicians",
      "Community and social services occupations",
      "Counselors, social workers, and other community and social service specialists",
      "Religious workers",
      "All other counselors, social, and religious workers",
      "Legal occupations",
      "Lawyers, judges, and related workers",
      "Legal support workers",
      "All other legal and related workers",
      "Education, training, and library occupations",
      "Postsecondary teachers",
      "Primary, secondary, and special education teachers",
      "Other teachers and instructors",
      "Librarians, curators, and archivists",
      "Other education, training, and library occupations",
      "Arts, design, entertainment, sports, and media occupations",
      "Art and design occupations",
      "Entertainers and performers, sports and related occupations",
      "Media and communication occupations",
      "Media and communication equipment occupations",
      "Healthcare practitioners and technical occupations",
      "Health diagnosing and treating practitioners",
      "Health technologists and technicians",
      "Other healthcare practitioners and technical occupations",
      "Healthcare support occupations",
      "Nursing, psychiatric, and home health aides",
      "Occupational and physical therapist assistants and aides",
      "Other healthcare support occupations",
      "Blue Collar",
      "Protective service occupations",
      "First-line supervisors/managers, protective service workers",
      "Fire fighting and prevention workers",
      "Law enforcement workers",
      "Other protective service workers",
      "Food preparation and serving related occupations",
      "Supervisors, food preparation and serving workers",
      "Cooks and food preparation workers",
      "Food and beverage serving workers",
      "Other food preparation and serving related workers",
      "Building and grounds cleaning and maintenance occupations",
      "Supervisors, building and grounds cleaning and maintenance workers",
      "Building cleaning and pest control workers",
      "Grounds maintenance workers",
      "All other building and grounds cleaning and maintenance workers",
      "Personal care and service occupations",
      "Supervisors, personal care and service workers",
      "Animal care and service workers",
      "Entertainment attendants and related workers",
      "Funeral service workers",
      "Personal appearance workers",
      "Transportation, tourism, and lodging attendants",
      "Other personal care and service workers",
      "Sales and related occupations",
      "Supervisors, sales workers",
      "Retail sales workers",
      "Sales representatives, services",
      "Sales representatives, wholesale and manufacturing",
      "Other sales and related workers",
      "Office and administrative support occupations",
      "Supervisors, office and administrative support workers",
      "Communications equipment operators",
      "Financial clerks",
      "Information and record clerks",
      "Material recording, scheduling, dispatching, and distributing occupations",
      "Secretaries and administrative assistants",
      "Other office and administrative support workers",
      "Farming, fishing, and forestry occupations",
      "Supervisors, farming, fishing, and forestry workers",
      "Agricultural workers",
      "Fishing and hunting workers",
      "Forest, conservation, and logging workers",
      "Construction and extraction occupations",
      "Supervisors, construction and extraction workers",
      "Construction trades and related workers",
      "Helpers, construction trades",
      "Other construction and related workers",
      "Extraction workers",
      "Installation, maintenance, and repair occupations",
      "Supervisors of installation, maintenance, and repair workers",
      "Electrical and electronic equipment mechanics, installers, and repairers",
      "And mobile equipment mechanics, installers, and repairers",
      "Other installation, maintenance, and repair occupations",
      "Production occupations",
      "Supervisors, production workers",
      "Assemblers and fabricators",
      "Food processing occupations",
      "Metal workers and plastic workers",
      "Printing occupations",
      "Textile, apparel, and furnishings occupations",
      "Woodworkers",
      "Plant and system operators",
      "Other production occupations",
      "Transportation and material moving occupations",
      "Supervisors, transportation and material moving workers",
      "Air transportation occupations",
      "Motor vehicle operators",
      "Rail transportation occupations",
      "Water transportation occupations",
      "Other transportation workers",
      "Material moving occupations",
      "Military",
      "Unclassified",
      "context.residential-population",
      "context.landarea"
    ],
    "id": "occupation",
    "name": "Occupation",
    "parameters": {
      "category": [
        {
          "description": null,
          "id": 2469,
          "label": "White Collar",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2470,
          "label": "Management occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2471,
          "label": "Top executives",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2472,
          "label": "Advertising, marketing, promotions, public relations, and sales managers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2473,
          "label": "Operations specialties managers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2474,
          "label": "Other management occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2475,
          "label": "Business and financial operations occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2476,
          "label": "Business operations specialists",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2477,
          "label": "Financial specialists",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2478,
          "label": "Computer and mathematical science occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2479,
          "label": "Computer specialists",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2480,
          "label": "Mathematical science occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2481,
          "label": "Architecture and engineering occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2482,
          "label": "Architects, surveyors, and cartographers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2483,
          "label": "Engineers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2484,
          "label": "Drafters, engineering, and mapping technicians",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2485,
          "label": "Life, physical, and social science occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2486,
          "label": "Life scientists",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2487,
          "label": "Physical scientists",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2488,
          "label": "Social scientists and related occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2489,
          "label": "Life, physical, and social science technicians",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2490,
          "label": "Community and social services occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2491,
          "label": "Counselors, social workers, and other community and social service specialists",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2492,
          "label": "Religious workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2493,
          "label": "All other counselors, social, and religious workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2494,
          "label": "Legal occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2495,
          "label": "Lawyers, judges, and related workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2496,
          "label": "Legal support workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2497,
          "label": "All other legal and related workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2498,
          "label": "Education, training, and library occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2499,
          "label": "Postsecondary teachers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2500,
          "label": "Primary, secondary, and special education teachers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2501,
          "label": "Other teachers and instructors",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2502,
          "label": "Librarians, curators, and archivists",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2503,
          "label": "Other education, training, and library occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2504,
          "label": "Arts, design, entertainment, sports, and media occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2505,
          "label": "Art and design occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2506,
          "label": "Entertainers and performers, sports and related occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2507,
          "label": "Media and communication occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2508,
          "label": "Media and communication equipment occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2509,
          "label": "Healthcare practitioners and technical occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2510,
          "label": "Health diagnosing and treating practitioners",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2511,
          "label": "Health technologists and technicians",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2512,
          "label": "Other healthcare practitioners and technical occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2513,
          "label": "Healthcare support occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2514,
          "label": "Nursing, psychiatric, and home health aides",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2515,
          "label": "Occupational and physical therapist assistants and aides",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2516,
          "label": "Other healthcare support occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2517,
          "label": "Blue Collar",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2518,
          "label": "Protective service occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2519,
          "label": "First-line supervisors/managers, protective service workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2520,
          "label": "Fire fighting and prevention workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2521,
          "label": "Law enforcement workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2522,
          "label": "Other protective service workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2523,
          "label": "Food preparation and serving related occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2524,
          "label": "Supervisors, food preparation and serving workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2525,
          "label": "Cooks and food preparation workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2526,
          "label": "Food and beverage serving workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2527,
          "label": "Other food preparation and serving related workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2528,
          "label": "Building and grounds cleaning and maintenance occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2529,
          "label": "Supervisors, building and grounds cleaning and maintenance workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2530,
          "label": "Building cleaning and pest control workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2531,
          "label": "Grounds maintenance workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2532,
          "label": "All other building and grounds cleaning and maintenance workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2533,
          "label": "Personal care and service occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2534,
          "label": "Supervisors, personal care and service workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2535,
          "label": "Animal care and service workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2536,
          "label": "Entertainment attendants and related workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2537,
          "label": "Funeral service workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2538,
          "label": "Personal appearance workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2539,
          "label": "Transportation, tourism, and lodging attendants",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2540,
          "label": "Other personal care and service workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2541,
          "label": "Sales and related occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2542,
          "label": "Supervisors, sales workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2543,
          "label": "Retail sales workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2544,
          "label": "Sales representatives, services",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2545,
          "label": "Sales representatives, wholesale and manufacturing",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2546,
          "label": "Other sales and related workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2547,
          "label": "Office and administrative support occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2548,
          "label": "Supervisors, office and administrative support workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2549,
          "label": "Communications equipment operators",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2550,
          "label": "Financial clerks",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2551,
          "label": "Information and record clerks",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2552,
          "label": "Material recording, scheduling, dispatching, and distributing occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2553,
          "label": "Secretaries and administrative assistants",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2554,
          "label": "Other office and administrative support workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2555,
          "label": "Farming, fishing, and forestry occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2556,
          "label": "Supervisors, farming, fishing, and forestry workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2557,
          "label": "Agricultural workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2558,
          "label": "Fishing and hunting workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2559,
          "label": "Forest, conservation, and logging workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2560,
          "label": "Construction and extraction occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2561,
          "label": "Supervisors, construction and extraction workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2562,
          "label": "Construction trades and related workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2563,
          "label": "Helpers, construction trades",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2564,
          "label": "Other construction and related workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2565,
          "label": "Extraction workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2566,
          "label": "Installation, maintenance, and repair occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2567,
          "label": "Supervisors of installation, maintenance, and repair workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2568,
          "label": "Electrical and electronic equipment mechanics, installers, and repairers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2569,
          "label": "And mobile equipment mechanics, installers, and repairers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2570,
          "label": "Other installation, maintenance, and repair occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2571,
          "label": "Production occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2572,
          "label": "Supervisors, production workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2573,
          "label": "Assemblers and fabricators",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2574,
          "label": "Food processing occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2575,
          "label": "Metal workers and plastic workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2576,
          "label": "Printing occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2577,
          "label": "Textile, apparel, and furnishings occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2578,
          "label": "Woodworkers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2579,
          "label": "Plant and system operators",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2580,
          "label": "Other production occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2581,
          "label": "Transportation and material moving occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2582,
          "label": "Supervisors, transportation and material moving workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2583,
          "label": "Air transportation occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2584,
          "label": "Motor vehicle operators",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2585,
          "label": "Rail transportation occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2586,
          "label": "Water transportation occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2587,
          "label": "Other transportation workers",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2588,
          "label": "Material moving occupations",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2589,
          "label": "Military",
          "parent_id": null
        },
        {
          "description": null,
          "id": 2590,
          "label": "Unclassified",
          "parent_id": null
        }
      ]
    },
    "periods": [
      "YR2020Q1"
    ],
    "slug": "occupation",
    "version": "v2"
  }
}
GET Query Insight at Location
{{baseUrl}}/data/insights/:insight_id:/query
HEADERS

X-RapidAPI-Key
X-RapidAPI-Host
QUERY PARAMS

version
location[]
insight_id
:
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-rapidapi-key: ");
headers = curl_slist_append(headers, "x-rapidapi-host: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/data/insights/:insight_id:/query" {:headers {:x-rapidapi-key ""
                                                                                      :x-rapidapi-host ""}
                                                                            :query-params {:version ""
                                                                                           :location[] ""}})
require "http/client"

url = "{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D="
headers = HTTP::Headers{
  "x-rapidapi-key" => ""
  "x-rapidapi-host" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D="),
    Headers =
    {
        { "x-rapidapi-key", "" },
        { "x-rapidapi-host", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D=");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-rapidapi-key", "");
request.AddHeader("x-rapidapi-host", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D="

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

	req.Header.Add("x-rapidapi-key", "")
	req.Header.Add("x-rapidapi-host", "")

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

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

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

}
GET /baseUrl/data/insights/:insight_id:/query?version=&location%5B%5D= HTTP/1.1
X-Rapidapi-Key: 
X-Rapidapi-Host: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D=")
  .setHeader("x-rapidapi-key", "")
  .setHeader("x-rapidapi-host", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D="))
    .header("x-rapidapi-key", "")
    .header("x-rapidapi-host", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D=")
  .get()
  .addHeader("x-rapidapi-key", "")
  .addHeader("x-rapidapi-host", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D=")
  .header("x-rapidapi-key", "")
  .header("x-rapidapi-host", "")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D=');
xhr.setRequestHeader('x-rapidapi-key', '');
xhr.setRequestHeader('x-rapidapi-host', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/data/insights/:insight_id:/query',
  params: {version: '', 'location[]': ''},
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D=';
const options = {method: 'GET', headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}};

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}}/data/insights/:insight_id:/query?version=&location%5B%5D=',
  method: 'GET',
  headers: {
    'x-rapidapi-key': '',
    'x-rapidapi-host': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D=")
  .get()
  .addHeader("x-rapidapi-key", "")
  .addHeader("x-rapidapi-host", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/data/insights/:insight_id:/query?version=&location%5B%5D=',
  headers: {
    'x-rapidapi-key': '',
    'x-rapidapi-host': ''
  }
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/data/insights/:insight_id:/query',
  qs: {version: '', 'location[]': ''},
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/data/insights/:insight_id:/query');

req.query({
  version: '',
  'location[]': ''
});

req.headers({
  'x-rapidapi-key': '',
  'x-rapidapi-host': ''
});

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/data/insights/:insight_id:/query',
  params: {version: '', 'location[]': ''},
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

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

const url = '{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D=';
const options = {method: 'GET', headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}};

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

NSDictionary *headers = @{ @"x-rapidapi-key": @"",
                           @"x-rapidapi-host": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D="]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/data/insights/:insight_id:/query?version=&location%5B%5D=" in
let headers = Header.add_list (Header.init ()) [
  ("x-rapidapi-key", "");
  ("x-rapidapi-host", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-rapidapi-host: ",
    "x-rapidapi-key: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D=', [
  'headers' => [
    'x-rapidapi-host' => '',
    'x-rapidapi-key' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/data/insights/:insight_id:/query');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'version' => '',
  'location[]' => ''
]);

$request->setHeaders([
  'x-rapidapi-key' => '',
  'x-rapidapi-host' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/data/insights/:insight_id:/query');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'version' => '',
  'location[]' => ''
]));

$request->setHeaders([
  'x-rapidapi-key' => '',
  'x-rapidapi-host' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-rapidapi-key", "")
$headers.Add("x-rapidapi-host", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D=' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-rapidapi-key", "")
$headers.Add("x-rapidapi-host", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D=' -Method GET -Headers $headers
import http.client

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

headers = {
    'x-rapidapi-key': "",
    'x-rapidapi-host': ""
}

conn.request("GET", "/baseUrl/data/insights/:insight_id:/query?version=&location%5B%5D=", headers=headers)

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

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

url = "{{baseUrl}}/data/insights/:insight_id:/query"

querystring = {"version":"","location[]":""}

headers = {
    "x-rapidapi-key": "",
    "x-rapidapi-host": ""
}

response = requests.get(url, headers=headers, params=querystring)

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

url <- "{{baseUrl}}/data/insights/:insight_id:/query"

queryString <- list(
  version = "",
  location[] = ""
)

response <- VERB("GET", url, query = queryString, add_headers('x-rapidapi-key' = '', 'x-rapidapi-host' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D=")

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

request = Net::HTTP::Get.new(url)
request["x-rapidapi-key"] = ''
request["x-rapidapi-host"] = ''

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

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

response = conn.get('/baseUrl/data/insights/:insight_id:/query') do |req|
  req.headers['x-rapidapi-key'] = ''
  req.headers['x-rapidapi-host'] = ''
  req.params['version'] = ''
  req.params['location[]'] = ''
end

puts response.status
puts response.body
use reqwest;

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

    let querystring = [
        ("version", ""),
        ("location[]", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-rapidapi-key", "".parse().unwrap());
    headers.insert("x-rapidapi-host", "".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url '{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D=' \
  --header 'x-rapidapi-host: ' \
  --header 'x-rapidapi-key: '
http GET '{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D=' \
  x-rapidapi-host:'' \
  x-rapidapi-key:''
wget --quiet \
  --method GET \
  --header 'x-rapidapi-key: ' \
  --header 'x-rapidapi-host: ' \
  --output-document \
  - '{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D='
import Foundation

let headers = [
  "x-rapidapi-key": "",
  "x-rapidapi-host": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/data/insights/:insight_id:/query?version=&location%5B%5D=")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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

dataTask.resume()
GET Fetch Nearest Road Segments
{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude
HEADERS

X-RapidAPI-Key
X-RapidAPI-Host
QUERY PARAMS

n
latitude
longitude
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n=");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-rapidapi-key: ");
headers = curl_slist_append(headers, "x-rapidapi-host: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude" {:headers {:x-rapidapi-key ""
                                                                                                :x-rapidapi-host ""}
                                                                                      :query-params {:n ""}})
require "http/client"

url = "{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n="
headers = HTTP::Headers{
  "x-rapidapi-key" => ""
  "x-rapidapi-host" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n="),
    Headers =
    {
        { "x-rapidapi-key", "" },
        { "x-rapidapi-host", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n=");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-rapidapi-key", "");
request.AddHeader("x-rapidapi-host", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n="

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

	req.Header.Add("x-rapidapi-key", "")
	req.Header.Add("x-rapidapi-host", "")

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

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

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

}
GET /baseUrl/traffic/roads/nearest/:latitude/:longitude?n= HTTP/1.1
X-Rapidapi-Key: 
X-Rapidapi-Host: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n=")
  .setHeader("x-rapidapi-key", "")
  .setHeader("x-rapidapi-host", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n="))
    .header("x-rapidapi-key", "")
    .header("x-rapidapi-host", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n=")
  .get()
  .addHeader("x-rapidapi-key", "")
  .addHeader("x-rapidapi-host", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n=")
  .header("x-rapidapi-key", "")
  .header("x-rapidapi-host", "")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n=');
xhr.setRequestHeader('x-rapidapi-key', '');
xhr.setRequestHeader('x-rapidapi-host', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude',
  params: {n: ''},
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n=';
const options = {method: 'GET', headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}};

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}}/traffic/roads/nearest/:latitude/:longitude?n=',
  method: 'GET',
  headers: {
    'x-rapidapi-key': '',
    'x-rapidapi-host': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n=")
  .get()
  .addHeader("x-rapidapi-key", "")
  .addHeader("x-rapidapi-host", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/traffic/roads/nearest/:latitude/:longitude?n=',
  headers: {
    'x-rapidapi-key': '',
    'x-rapidapi-host': ''
  }
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude',
  qs: {n: ''},
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude');

req.query({
  n: ''
});

req.headers({
  'x-rapidapi-key': '',
  'x-rapidapi-host': ''
});

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude',
  params: {n: ''},
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

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

const url = '{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n=';
const options = {method: 'GET', headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}};

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

NSDictionary *headers = @{ @"x-rapidapi-key": @"",
                           @"x-rapidapi-host": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n="]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/traffic/roads/nearest/:latitude/:longitude?n=" in
let headers = Header.add_list (Header.init ()) [
  ("x-rapidapi-key", "");
  ("x-rapidapi-host", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n=",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-rapidapi-host: ",
    "x-rapidapi-key: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n=', [
  'headers' => [
    'x-rapidapi-host' => '',
    'x-rapidapi-key' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'n' => ''
]);

$request->setHeaders([
  'x-rapidapi-key' => '',
  'x-rapidapi-host' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'n' => ''
]));

$request->setHeaders([
  'x-rapidapi-key' => '',
  'x-rapidapi-host' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-rapidapi-key", "")
$headers.Add("x-rapidapi-host", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n=' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-rapidapi-key", "")
$headers.Add("x-rapidapi-host", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n=' -Method GET -Headers $headers
import http.client

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

headers = {
    'x-rapidapi-key': "",
    'x-rapidapi-host': ""
}

conn.request("GET", "/baseUrl/traffic/roads/nearest/:latitude/:longitude?n=", headers=headers)

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

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

url = "{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude"

querystring = {"n":""}

headers = {
    "x-rapidapi-key": "",
    "x-rapidapi-host": ""
}

response = requests.get(url, headers=headers, params=querystring)

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

url <- "{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude"

queryString <- list(n = "")

response <- VERB("GET", url, query = queryString, add_headers('x-rapidapi-key' = '', 'x-rapidapi-host' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n=")

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

request = Net::HTTP::Get.new(url)
request["x-rapidapi-key"] = ''
request["x-rapidapi-host"] = ''

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

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

response = conn.get('/baseUrl/traffic/roads/nearest/:latitude/:longitude') do |req|
  req.headers['x-rapidapi-key'] = ''
  req.headers['x-rapidapi-host'] = ''
  req.params['n'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude";

    let querystring = [
        ("n", ""),
    ];

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-rapidapi-key", "".parse().unwrap());
    headers.insert("x-rapidapi-host", "".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url '{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n=' \
  --header 'x-rapidapi-host: ' \
  --header 'x-rapidapi-key: '
http GET '{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n=' \
  x-rapidapi-host:'' \
  x-rapidapi-key:''
wget --quiet \
  --method GET \
  --header 'x-rapidapi-key: ' \
  --header 'x-rapidapi-host: ' \
  --output-document \
  - '{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n='
import Foundation

let headers = [
  "x-rapidapi-key": "",
  "x-rapidapi-host": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/traffic/roads/nearest/:latitude/:longitude?n=")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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/json; charset=utf-8
RESPONSE BODY json

{
  "data": {
    "crs": {
      "properties": {
        "name": "urn:ogc:def:crs:OGC:1.3:CRS84"
      },
      "type": "name"
    },
    "features": [
      {
        "geometry": {
          "coordinates": [
            [
              -97.735557,
              30.261986
            ],
            [
              -97.735196,
              30.26292
            ],
            [
              -97.735011,
              30.263339
            ],
            [
              -97.734814,
              30.263796
            ],
            [
              -97.7347722,
              30.2638848
            ],
            [
              -97.734748,
              30.263936
            ],
            [
              -97.734723,
              30.264008
            ],
            [
              -97.734617,
              30.26428
            ],
            [
              -97.734489,
              30.264667
            ],
            [
              -97.734447,
              30.2648
            ],
            [
              -97.734362,
              30.26507
            ],
            [
              -97.734288,
              30.265273
            ],
            [
              -97.734177,
              30.265612
            ],
            [
              -97.734165,
              30.265642
            ]
          ],
          "type": "LineString"
        },
        "properties": {
          "bearing": "N",
          "roadname": "North Interstate Highway 35 Service Road",
          "segment_id": "1595171804",
          "state": "Texas"
        },
        "type": "Feature"
      }
    ],
    "type": "FeatureCollection"
  }
}
GET Vehicle Traffic Counts for Road Segment
{{baseUrl}}/traffic/counts/:segment_id
HEADERS

X-RapidAPI-Key
X-RapidAPI-Host
QUERY PARAMS

segment_id
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/traffic/counts/:segment_id");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "x-rapidapi-key: ");
headers = curl_slist_append(headers, "x-rapidapi-host: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/traffic/counts/:segment_id" {:headers {:x-rapidapi-key ""
                                                                                :x-rapidapi-host ""}})
require "http/client"

url = "{{baseUrl}}/traffic/counts/:segment_id"
headers = HTTP::Headers{
  "x-rapidapi-key" => ""
  "x-rapidapi-host" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/traffic/counts/:segment_id"),
    Headers =
    {
        { "x-rapidapi-key", "" },
        { "x-rapidapi-host", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/traffic/counts/:segment_id");
var request = new RestRequest("", Method.Get);
request.AddHeader("x-rapidapi-key", "");
request.AddHeader("x-rapidapi-host", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/traffic/counts/:segment_id"

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

	req.Header.Add("x-rapidapi-key", "")
	req.Header.Add("x-rapidapi-host", "")

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

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

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

}
GET /baseUrl/traffic/counts/:segment_id HTTP/1.1
X-Rapidapi-Key: 
X-Rapidapi-Host: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/traffic/counts/:segment_id")
  .setHeader("x-rapidapi-key", "")
  .setHeader("x-rapidapi-host", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/traffic/counts/:segment_id"))
    .header("x-rapidapi-key", "")
    .header("x-rapidapi-host", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/traffic/counts/:segment_id")
  .get()
  .addHeader("x-rapidapi-key", "")
  .addHeader("x-rapidapi-host", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/traffic/counts/:segment_id")
  .header("x-rapidapi-key", "")
  .header("x-rapidapi-host", "")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/traffic/counts/:segment_id');
xhr.setRequestHeader('x-rapidapi-key', '');
xhr.setRequestHeader('x-rapidapi-host', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/traffic/counts/:segment_id',
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/traffic/counts/:segment_id';
const options = {method: 'GET', headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}};

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}}/traffic/counts/:segment_id',
  method: 'GET',
  headers: {
    'x-rapidapi-key': '',
    'x-rapidapi-host': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/traffic/counts/:segment_id")
  .get()
  .addHeader("x-rapidapi-key", "")
  .addHeader("x-rapidapi-host", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/traffic/counts/:segment_id',
  headers: {
    'x-rapidapi-key': '',
    'x-rapidapi-host': ''
  }
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/traffic/counts/:segment_id',
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/traffic/counts/:segment_id');

req.headers({
  'x-rapidapi-key': '',
  'x-rapidapi-host': ''
});

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/traffic/counts/:segment_id',
  headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}
};

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

const url = '{{baseUrl}}/traffic/counts/:segment_id';
const options = {method: 'GET', headers: {'x-rapidapi-key': '', 'x-rapidapi-host': ''}};

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

NSDictionary *headers = @{ @"x-rapidapi-key": @"",
                           @"x-rapidapi-host": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/traffic/counts/:segment_id"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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}}/traffic/counts/:segment_id" in
let headers = Header.add_list (Header.init ()) [
  ("x-rapidapi-key", "");
  ("x-rapidapi-host", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/traffic/counts/:segment_id",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "x-rapidapi-host: ",
    "x-rapidapi-key: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/traffic/counts/:segment_id', [
  'headers' => [
    'x-rapidapi-host' => '',
    'x-rapidapi-key' => '',
  ],
]);

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

$request->setHeaders([
  'x-rapidapi-key' => '',
  'x-rapidapi-host' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/traffic/counts/:segment_id');
$request->setRequestMethod('GET');
$request->setHeaders([
  'x-rapidapi-key' => '',
  'x-rapidapi-host' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("x-rapidapi-key", "")
$headers.Add("x-rapidapi-host", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/traffic/counts/:segment_id' -Method GET -Headers $headers
$headers=@{}
$headers.Add("x-rapidapi-key", "")
$headers.Add("x-rapidapi-host", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/traffic/counts/:segment_id' -Method GET -Headers $headers
import http.client

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

headers = {
    'x-rapidapi-key': "",
    'x-rapidapi-host': ""
}

conn.request("GET", "/baseUrl/traffic/counts/:segment_id", headers=headers)

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

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

url = "{{baseUrl}}/traffic/counts/:segment_id"

headers = {
    "x-rapidapi-key": "",
    "x-rapidapi-host": ""
}

response = requests.get(url, headers=headers)

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

url <- "{{baseUrl}}/traffic/counts/:segment_id"

response <- VERB("GET", url, add_headers('x-rapidapi-key' = '', 'x-rapidapi-host' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/traffic/counts/:segment_id")

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

request = Net::HTTP::Get.new(url)
request["x-rapidapi-key"] = ''
request["x-rapidapi-host"] = ''

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

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

response = conn.get('/baseUrl/traffic/counts/:segment_id') do |req|
  req.headers['x-rapidapi-key'] = ''
  req.headers['x-rapidapi-host'] = ''
end

puts response.status
puts response.body
use reqwest;

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("x-rapidapi-key", "".parse().unwrap());
    headers.insert("x-rapidapi-host", "".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/traffic/counts/:segment_id \
  --header 'x-rapidapi-host: ' \
  --header 'x-rapidapi-key: '
http GET {{baseUrl}}/traffic/counts/:segment_id \
  x-rapidapi-host:'' \
  x-rapidapi-key:''
wget --quiet \
  --method GET \
  --header 'x-rapidapi-key: ' \
  --header 'x-rapidapi-host: ' \
  --output-document \
  - {{baseUrl}}/traffic/counts/:segment_id
import Foundation

let headers = [
  "x-rapidapi-key": "",
  "x-rapidapi-host": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/traffic/counts/:segment_id")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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/json; charset=utf-8
RESPONSE BODY json

{
  "data": [
    {
      "data": [
        [
          81,
          56,
          35,
          26,
          28,
          48,
          86,
          130,
          182,
          240,
          292,
          334,
          360,
          360,
          357,
          353,
          339,
          307,
          266,
          222,
          188,
          158,
          125,
          102
        ],
        [
          34,
          35,
          30,
          33,
          55,
          153,
          371,
          494,
          402,
          327,
          336,
          369,
          390,
          386,
          402,
          423,
          419,
          379,
          303,
          243,
          200,
          163,
          118,
          69
        ],
        [
          34,
          35,
          30,
          33,
          55,
          153,
          371,
          494,
          402,
          327,
          336,
          369,
          390,
          386,
          402,
          423,
          419,
          379,
          303,
          243,
          200,
          163,
          118,
          69
        ],
        [
          34,
          35,
          30,
          33,
          55,
          153,
          371,
          494,
          402,
          327,
          336,
          369,
          390,
          386,
          402,
          423,
          419,
          379,
          303,
          243,
          200,
          163,
          118,
          69
        ],
        [
          34,
          35,
          30,
          33,
          55,
          153,
          371,
          494,
          402,
          327,
          336,
          369,
          390,
          386,
          402,
          423,
          419,
          379,
          303,
          243,
          200,
          163,
          118,
          69
        ],
        [
          37,
          37,
          32,
          35,
          59,
          160,
          388,
          518,
          421,
          343,
          352,
          387,
          409,
          406,
          422,
          443,
          439,
          396,
          318,
          255,
          210,
          171,
          122,
          73
        ],
        [
          91,
          62,
          40,
          28,
          31,
          55,
          98,
          146,
          204,
          271,
          330,
          377,
          404,
          404,
          404,
          398,
          381,
          346,
          298,
          250,
          212,
          178,
          141,
          114
        ]
      ],
      "metadata": {
        "bearing": "W",
        "columns": [
          "12:00am",
          "01:00am",
          "02:00am",
          "03:00am",
          "04:00am",
          "05:00am",
          "06:00am",
          "07:00am",
          "08:00am",
          "09:00am",
          "10:00am",
          "11:00am",
          "12:00pm",
          "01:00pm",
          "02:00pm",
          "03:00pm",
          "04:00pm",
          "05:00pm",
          "06:00pm",
          "07:00pm",
          "08:00pm",
          "09:00pm",
          "10:00pm",
          "11:00pm"
        ],
        "name": "East 6th Street",
        "rows": [
          "Sun",
          "Mon",
          "Tue",
          "Wed",
          "Thu",
          "Fri",
          "Sat"
        ],
        "segment_id": "1595369397",
        "state": "Texas"
      },
      "roadsegment": {
        "coordinates": [
          [
            -97.734165,
            30.265642000000014
          ],
          [
            -97.734314,
            30.265693999999996
          ],
          [
            -97.734409,
            30.265727999999996
          ],
          [
            -97.7345332,
            30.265769000000006
          ],
          [
            -97.7346688,
            30.265802199999996
          ],
          [
            -97.7349238,
            30.2658816
          ],
          [
            -97.7350156,
            30.265904199999994
          ]
        ],
        "type": "LineString"
      },
      "stats": {
        "aadt": 5843
      }
    },
    {
      "data": [
        [
          116,
          80,
          51,
          36,
          41,
          69,
          124,
          185,
          259,
          343,
          416,
          476,
          512,
          512,
          509,
          502,
          482,
          437,
          379,
          317,
          267,
          226,
          178,
          145
        ],
        [
          71,
          43,
          34,
          37,
          69,
          173,
          364,
          485,
          464,
          438,
          469,
          520,
          548,
          561,
          610,
          666,
          677,
          625,
          503,
          413,
          346,
          279,
          203,
          134
        ],
        [
          71,
          43,
          34,
          37,
          69,
          173,
          364,
          485,
          464,
          438,
          469,
          520,
          548,
          561,
          610,
          666,
          677,
          625,
          503,
          413,
          346,
          279,
          203,
          134
        ],
        [
          71,
          43,
          34,
          37,
          69,
          173,
          364,
          485,
          464,
          438,
          469,
          520,
          548,
          561,
          610,
          666,
          677,
          625,
          503,
          413,
          346,
          279,
          203,
          134
        ],
        [
          71,
          43,
          34,
          37,
          69,
          173,
          364,
          485,
          464,
          438,
          469,
          520,
          548,
          561,
          610,
          666,
          677,
          625,
          503,
          413,
          346,
          279,
          203,
          134
        ],
        [
          74,
          46,
          34,
          38,
          73,
          180,
          382,
          509,
          487,
          458,
          491,
          545,
          576,
          587,
          640,
          698,
          710,
          654,
          528,
          433,
          362,
          292,
          213,
          141
        ],
        [
          130,
          88,
          57,
          40,
          45,
          78,
          138,
          207,
          291,
          386,
          469,
          536,
          576,
          576,
          573,
          566,
          542,
          493,
          426,
          356,
          299,
          253,
          201,
          163
        ]
      ],
      "metadata": {
        "bearing": "E",
        "columns": [
          "12:00am",
          "01:00am",
          "02:00am",
          "03:00am",
          "04:00am",
          "05:00am",
          "06:00am",
          "07:00am",
          "08:00am",
          "09:00am",
          "10:00am",
          "11:00am",
          "12:00pm",
          "01:00pm",
          "02:00pm",
          "03:00pm",
          "04:00pm",
          "05:00pm",
          "06:00pm",
          "07:00pm",
          "08:00pm",
          "09:00pm",
          "10:00pm",
          "11:00pm"
        ],
        "name": "East 6th Street",
        "rows": [
          "Sun",
          "Mon",
          "Tue",
          "Wed",
          "Thu",
          "Fri",
          "Sat"
        ],
        "segment_id": "1595369411",
        "state": "Texas"
      },
      "roadsegment": {
        "coordinates": [
          [
            -97.7350156,
            30.265904199999994
          ],
          [
            -97.7349238,
            30.2658816
          ],
          [
            -97.7346688,
            30.265802199999996
          ],
          [
            -97.7345332,
            30.265769000000006
          ],
          [
            -97.734409,
            30.265727999999996
          ],
          [
            -97.734314,
            30.265693999999996
          ],
          [
            -97.734165,
            30.265642000000014
          ]
        ],
        "type": "LineString"
      },
      "stats": {
        "aadt": 8318
      }
    }
  ]
}