diff --git a/sdk/search/azure-search-documents/tests/async_tests/test_search_client_basic_live_async.py b/sdk/search/azure-search-documents/tests/async_tests/test_search_client_basic_live_async.py index 993adeabca7c..f82fcab71705 100644 --- a/sdk/search/azure-search-documents/tests/async_tests/test_search_client_basic_live_async.py +++ b/sdk/search/azure-search-documents/tests/async_tests/test_search_client_basic_live_async.py @@ -3,79 +3,43 @@ # Licensed under the MIT License. See License.txt in the project root for # license information. # -------------------------------------------------------------------------- -import asyncio -import functools -import json -from os.path import dirname, join, realpath import pytest - -from devtools_testutils import AzureMgmtTestCase, ResourceGroupPreparer -from azure_devtools.scenario_tests import ReplayableTest - -from search_service_preparer import SearchServicePreparer - -from azure_devtools.scenario_tests.utilities import trim_kwargs_from_test_function - -CWD = dirname(realpath(__file__)) - -SCHEMA = open(join(CWD, "..", "hotel_schema.json")).read() -BATCH = json.load(open(join(CWD, "..", "hotel_small.json"), encoding='utf-8')) - from azure.core.exceptions import HttpResponseError -from azure.core.credentials import AzureKeyCredential from azure.search.documents.aio import SearchClient +from devtools_testutils.aio import recorded_by_proxy_async +from devtools_testutils import AzureRecordedTestCase -TIME_TO_SLEEP = 3 - -def await_prepared_test(test_fn): - """Synchronous wrapper for async test methods. Used to avoid making changes - upstream to AbstractPreparer (which doesn't await the functions it wraps) - """ - - @functools.wraps(test_fn) - def run(test_class_instance, *args, **kwargs): - trim_kwargs_from_test_function(test_fn, kwargs) - loop = asyncio.get_event_loop() - return loop.run_until_complete(test_fn(test_class_instance, **kwargs)) - - return run - +from search_service_preparer import SearchEnvVarPreparer, search_decorator -class SearchClientTestAsync(AzureMgmtTestCase): - FILTER_HEADERS = ReplayableTest.FILTER_HEADERS + ['api-key'] +class TestSearchClientAsync(AzureRecordedTestCase): - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_async_get_document_count( - self, api_key, endpoint, index_name, **kwargs - ): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy_async + async def test_get_document_count(self, endpoint, api_key, index_name): + client = SearchClient(endpoint, index_name, api_key) async with client: assert await client.get_document_count() == 10 - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_document(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy_async + async def test_get_document(self, endpoint, api_key, index_name, index_batch): + client = SearchClient(endpoint, index_name, api_key) async with client: for hotel_id in range(1, 11): result = await client.get_document(key=str(hotel_id)) - expected = BATCH["value"][hotel_id - 1] + expected = index_batch["value"][hotel_id - 1] assert result.get("hotelId") == expected.get("hotelId") assert result.get("hotelName") == expected.get("hotelName") assert result.get("description") == expected.get("description") - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_document_missing(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy_async + async def test_get_document_missing(self, endpoint, api_key, index_name): + client = SearchClient(endpoint, index_name, api_key) async with client: with pytest.raises(HttpResponseError): await client.get_document(key="1000") diff --git a/sdk/search/azure-search-documents/tests/async_tests/test_search_client_buffered_sender_live_async.py b/sdk/search/azure-search-documents/tests/async_tests/test_search_client_buffered_sender_live_async.py index d889a83cb5db..9105c7ca099f 100644 --- a/sdk/search/azure-search-documents/tests/async_tests/test_search_client_buffered_sender_live_async.py +++ b/sdk/search/azure-search-documents/tests/async_tests/test_search_client_buffered_sender_live_async.py @@ -3,251 +3,170 @@ # Licensed under the MIT License. See License.txt in the project root for # license information. # -------------------------------------------------------------------------- -import asyncio -import functools -import json -from os.path import dirname, join, realpath -import time import pytest - -from devtools_testutils import AzureMgmtTestCase, ResourceGroupPreparer -from azure_devtools.scenario_tests import ReplayableTest -from azure_devtools.scenario_tests.utilities import trim_kwargs_from_test_function - -from search_service_preparer import SearchServicePreparer - -CWD = dirname(realpath(__file__)) - -SCHEMA = open(join(CWD, "..", "hotel_schema.json")).read() -BATCH = json.load(open(join(CWD, "..", "hotel_small.json"), encoding='utf-8')) - +import time from azure.core.exceptions import HttpResponseError from azure.core.credentials import AzureKeyCredential -from azure.search.documents.aio import SearchClient, SearchIndexingBufferedSender +from azure.search.documents.aio import SearchIndexingBufferedSender, SearchClient +from devtools_testutils import AzureRecordedTestCase +from devtools_testutils.aio import recorded_by_proxy_async +from search_service_preparer import SearchEnvVarPreparer, search_decorator TIME_TO_SLEEP = 3 -def await_prepared_test(test_fn): - """Synchronous wrapper for async test methods. Used to avoid making changes - upstream to AbstractPreparer (which doesn't await the functions it wraps) - """ - @functools.wraps(test_fn) - def run(test_class_instance, *args, **kwargs): - trim_kwargs_from_test_function(test_fn, kwargs) - loop = asyncio.get_event_loop() - return loop.run_until_complete(test_fn(test_class_instance, **kwargs)) - - return run - - -class SearchClientTestAsync(AzureMgmtTestCase): - FILTER_HEADERS = ReplayableTest.FILTER_HEADERS + ['api-key'] - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_upload_documents_new(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - batch_client = SearchIndexingBufferedSender( - endpoint, index_name, AzureKeyCredential(api_key) - ) +class TestSearchIndexingBufferedSenderAsync(AzureRecordedTestCase): + + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy_async + async def test_search_client_index_buffered_sender(self, endpoint, api_key, index_name): + client = SearchClient(endpoint, index_name, api_key) + batch_client = SearchIndexingBufferedSender(endpoint, index_name, api_key) + try: + async with client: + async with batch_client: + doc_count = 10 + doc_count = await self._test_upload_documents_new(client, batch_client, doc_count) + doc_count = await self._test_upload_documents_existing(client, batch_client, doc_count) + doc_count = await self._test_delete_documents_existing(client, batch_client, doc_count) + doc_count = await self._test_delete_documents_missing(client, batch_client, doc_count) + doc_count = await self._test_merge_documents_existing(client, batch_client, doc_count) + doc_count = await self._test_merge_documents_missing(client, batch_client, doc_count) + doc_count = await self._test_merge_or_upload_documents(client, batch_client, doc_count) + finally: + batch_client.close() + + async def _test_upload_documents_new(self, client, batch_client, doc_count): batch_client._batch_action_count = 2 - DOCUMENTS = [ + docs = [ {"hotelId": "1000", "rating": 5, "rooms": [], "hotelName": "Azure Inn"}, {"hotelId": "1001", "rating": 4, "rooms": [], "hotelName": "Redmond Hotel"}, ] - - async with batch_client: - await batch_client.upload_documents(DOCUMENTS) + await batch_client.upload_documents(docs) + doc_count += 2 # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - async with client: - assert await client.get_document_count() == 12 - for doc in DOCUMENTS: - result = await client.get_document(key=doc["hotelId"]) - assert result["hotelId"] == doc["hotelId"] - assert result["hotelName"] == doc["hotelName"] - assert result["rating"] == doc["rating"] - assert result["rooms"] == doc["rooms"] - - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_upload_documents_existing( - self, api_key, endpoint, index_name, **kwargs - ): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - batch_client = SearchIndexingBufferedSender( - endpoint, index_name, AzureKeyCredential(api_key) - ) + + assert await client.get_document_count() == doc_count + for doc in docs: + result = await client.get_document(key=doc["hotelId"]) + assert result["hotelId"] == doc["hotelId"] + assert result["hotelName"] == doc["hotelName"] + assert result["rating"] == doc["rating"] + assert result["rooms"] == doc["rooms"] + return doc_count + + async def _test_upload_documents_existing(self, client, batch_client, doc_count): batch_client._batch_action_count = 2 - DOCUMENTS = [ - {"hotelId": "1000", "rating": 5, "rooms": [], "hotelName": "Azure Inn"}, + # add one new and one existing + docs = [ + {"hotelId": "1002", "rating": 5, "rooms": [], "hotelName": "Azure Inn"}, {"hotelId": "3", "rating": 4, "rooms": [], "hotelName": "Redmond Hotel"}, ] - async with batch_client: - await batch_client.upload_documents(DOCUMENTS) + await batch_client.upload_documents(docs) + doc_count += 1 # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - async with client: - assert await client.get_document_count() == 11 - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_delete_documents_existing( - self, api_key, endpoint, index_name, **kwargs - ): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - batch_client = SearchIndexingBufferedSender( - endpoint, index_name, AzureKeyCredential(api_key) - ) + assert await client.get_document_count() == doc_count + return doc_count + + async def _test_delete_documents_existing(self, client, batch_client, doc_count): batch_client._batch_action_count = 2 - async with batch_client: - await batch_client.delete_documents( - [{"hotelId": "3"}, {"hotelId": "4"}] - ) + docs = [{"hotelId": "3"}, {"hotelId": "4"}] + await batch_client.delete_documents(docs) + doc_count -= 2 # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - async with client: - assert await client.get_document_count() == 8 - - with pytest.raises(HttpResponseError): - await client.get_document(key="3") - - with pytest.raises(HttpResponseError): - await client.get_document(key="4") - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_delete_documents_missing( - self, api_key, endpoint, index_name, **kwargs - ): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - batch_client = SearchIndexingBufferedSender( - endpoint, index_name, AzureKeyCredential(api_key) - ) + assert await client.get_document_count() == doc_count + + with pytest.raises(HttpResponseError): + await client.get_document(key="3") + + with pytest.raises(HttpResponseError): + await client.get_document(key="4") + return doc_count + + async def _test_delete_documents_missing(self, client, batch_client, doc_count): batch_client._batch_action_count = 2 - async with batch_client: - await batch_client.delete_documents( - [{"hotelId": "1000"}, {"hotelId": "4"}] - ) + # delete one existing and one missing + docs = [{"hotelId": "1003"}, {"hotelId": "2"}] + await batch_client.delete_documents(docs) + doc_count -= 1 # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - async with client: - assert await client.get_document_count() == 9 - - with pytest.raises(HttpResponseError): - await client.get_document(key="1000") - - with pytest.raises(HttpResponseError): - await client.get_document(key="4") - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_merge_documents_existing( - self, api_key, endpoint, index_name, **kwargs - ): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - batch_client = SearchIndexingBufferedSender( - endpoint, index_name, AzureKeyCredential(api_key) - ) + assert await client.get_document_count() == doc_count + with pytest.raises(HttpResponseError): + await client.get_document(key="1003") + with pytest.raises(HttpResponseError): + await client.get_document(key="2") + return doc_count + + async def _test_merge_documents_existing(self, client, batch_client, doc_count): batch_client._batch_action_count = 2 - async with batch_client: - await batch_client.merge_documents( - [{"hotelId": "3", "rating": 1}, {"hotelId": "4", "rating": 2}] - ) + docs = [{"hotelId": "5", "rating": 1}, {"hotelId": "6", "rating": 2}] + await batch_client.merge_documents(docs) # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - async with client: - assert await client.get_document_count() == 10 - - result = await client.get_document(key="3") - assert result["rating"] == 1 - - result = await client.get_document(key="4") - assert result["rating"] == 2 - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_merge_documents_missing( - self, api_key, endpoint, index_name, **kwargs - ): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - batch_client = SearchIndexingBufferedSender( - endpoint, index_name, AzureKeyCredential(api_key) - ) + assert await client.get_document_count() == doc_count + + result = await client.get_document(key="5") + assert result["rating"] == 1 + + result = await client.get_document(key="6") + assert result["rating"] == 2 + return doc_count + + async def _test_merge_documents_missing(self, client, batch_client, doc_count): batch_client._batch_action_count = 2 - async with batch_client: - await batch_client.merge_documents( - [{"hotelId": "1000", "rating": 1}, {"hotelId": "4", "rating": 2}] - ) + # merge to one existing and one missing document + docs = [{"hotelId": "1003", "rating": 1}, {"hotelId": "1", "rating": 2}] + await batch_client.merge_documents(docs) # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - async with client: - assert await client.get_document_count() == 10 - - with pytest.raises(HttpResponseError): - await client.get_document(key="1000") - - result = await client.get_document(key="4") - assert result["rating"] == 2 - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_merge_or_upload_documents( - self, api_key, endpoint, index_name, **kwargs - ): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - batch_client = SearchIndexingBufferedSender( - endpoint, index_name, AzureKeyCredential(api_key) - ) + assert await client.get_document_count() == doc_count + + with pytest.raises(HttpResponseError): + await client.get_document(key="1003") + + result = await client.get_document(key="1") + assert result["rating"] == 2 + return doc_count + + async def _test_merge_or_upload_documents(self, client, batch_client, doc_count): batch_client._batch_action_count = 2 - async with batch_client: - await batch_client.merge_or_upload_documents( - [{"hotelId": "1000", "rating": 1}, {"hotelId": "4", "rating": 2}] - ) + # merge to one existing and one missing + docs = [{"hotelId": "1003", "rating": 1}, {"hotelId": "1", "rating": 2}] + await batch_client.merge_or_upload_documents(docs) + doc_count += 1 # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - async with client: - assert await client.get_document_count() == 11 + assert await client.get_document_count() == doc_count - result = await client.get_document(key="1000") - assert result["rating"] == 1 + result = await client.get_document(key="1003") + assert result["rating"] == 1 - result = await client.get_document(key="4") - assert result["rating"] == 2 + result = await client.get_document(key="1") + assert result["rating"] == 2 + return doc_count diff --git a/sdk/search/azure-search-documents/tests/async_tests/test_search_client_index_document_live_async.py b/sdk/search/azure-search-documents/tests/async_tests/test_search_client_index_document_live_async.py index 71bb591f65d7..6d506127f116 100644 --- a/sdk/search/azure-search-documents/tests/async_tests/test_search_client_index_document_live_async.py +++ b/sdk/search/azure-search-documents/tests/async_tests/test_search_client_index_document_live_async.py @@ -3,224 +3,168 @@ # Licensed under the MIT License. See License.txt in the project root for # license information. # -------------------------------------------------------------------------- -import asyncio -import functools -import json -from os.path import dirname, join, realpath -import time +from pydoc import doc import pytest - -from devtools_testutils import AzureMgmtTestCase, ResourceGroupPreparer -from azure_devtools.scenario_tests import ReplayableTest -from azure_devtools.scenario_tests.utilities import trim_kwargs_from_test_function - -from search_service_preparer import SearchServicePreparer - -CWD = dirname(realpath(__file__)) - -SCHEMA = open(join(CWD, "..", "hotel_schema.json")).read() -BATCH = json.load(open(join(CWD, "..", "hotel_small.json"), encoding='utf-8')) - +import time from azure.core.exceptions import HttpResponseError -from azure.core.credentials import AzureKeyCredential from azure.search.documents.aio import SearchClient +from devtools_testutils import AzureRecordedTestCase +from devtools_testutils.aio import recorded_by_proxy_async +from search_service_preparer import SearchEnvVarPreparer, search_decorator TIME_TO_SLEEP = 3 -def await_prepared_test(test_fn): - """Synchronous wrapper for async test methods. Used to avoid making changes - upstream to AbstractPreparer (which doesn't await the functions it wraps) - """ - - @functools.wraps(test_fn) - def run(test_class_instance, *args, **kwargs): - trim_kwargs_from_test_function(test_fn, kwargs) - loop = asyncio.get_event_loop() - return loop.run_until_complete(test_fn(test_class_instance, **kwargs)) - - return run +class TestSearchClientDocumentsAsync(AzureRecordedTestCase): -class SearchClientTestAsync(AzureMgmtTestCase): - FILTER_HEADERS = ReplayableTest.FILTER_HEADERS + ['api-key'] - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_upload_documents_new(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - DOCUMENTS = [ + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy_async + async def test_search_client_index_document(self, endpoint, api_key, index_name): + client = SearchClient(endpoint, index_name, api_key) + doc_count = 10 + async with client: + doc_count = await self._test_upload_documents_new(client, doc_count) + doc_count = await self._test_upload_documents_existing(client, doc_count) + doc_count = await self._test_delete_documents_existing(client, doc_count) + doc_count = await self._test_delete_documents_missing(client, doc_count) + doc_count = await self._test_merge_documents_existing(client, doc_count) + doc_count = await self._test_merge_documents_missing(client, doc_count) + doc_count = await self._test_merge_or_upload_documents(client, doc_count) + + async def _test_upload_documents_new(self, client, doc_count): + docs = [ {"hotelId": "1000", "rating": 5, "rooms": [], "hotelName": "Azure Inn"}, {"hotelId": "1001", "rating": 4, "rooms": [], "hotelName": "Redmond Hotel"}, ] - - async with client: - results = await client.upload_documents(DOCUMENTS) - assert len(results) == 2 - assert set(x.status_code for x in results) == {201} - - # There can be some lag before a document is searchable - if self.is_live: - time.sleep(TIME_TO_SLEEP) - - assert await client.get_document_count() == 12 - for doc in DOCUMENTS: - result = await client.get_document(key=doc["hotelId"]) - assert result["hotelId"] == doc["hotelId"] - assert result["hotelName"] == doc["hotelName"] - assert result["rating"] == doc["rating"] - assert result["rooms"] == doc["rooms"] - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_upload_documents_existing( - self, api_key, endpoint, index_name, **kwargs - ): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - DOCUMENTS = [ - {"hotelId": "1000", "rating": 5, "rooms": [], "hotelName": "Azure Inn"}, + results = await client.upload_documents(docs) + assert len(results) == len(docs) + assert set(x.status_code for x in results) == {201} + doc_count += len(docs) + + # There can be some lag before a document is searchable + if self.is_live: + time.sleep(TIME_TO_SLEEP) + + assert await client.get_document_count() == doc_count + for doc in docs: + result = await client.get_document(key=doc["hotelId"]) + assert result["hotelId"] == doc["hotelId"] + assert result["hotelName"] == doc["hotelName"] + assert result["rating"] == doc["rating"] + assert result["rooms"] == doc["rooms"] + return doc_count + + async def _test_upload_documents_existing(self, client, doc_count): + # add one new and one existing + docs = [ + {"hotelId": "1002", "rating": 5, "rooms": [], "hotelName": "Azure Inn"}, {"hotelId": "3", "rating": 4, "rooms": [], "hotelName": "Redmond Hotel"}, ] - async with client: - results = await client.upload_documents(DOCUMENTS) - assert len(results) == 2 - assert set(x.status_code for x in results) == {200, 201} - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_delete_documents_existing( - self, api_key, endpoint, index_name, **kwargs - ): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - async with client: - results = await client.delete_documents( - [{"hotelId": "3"}, {"hotelId": "4"}] - ) - assert len(results) == 2 - assert set(x.status_code for x in results) == {200} - - # There can be some lag before a document is searchable - if self.is_live: - time.sleep(TIME_TO_SLEEP) - - assert await client.get_document_count() == 8 - - with pytest.raises(HttpResponseError): - await client.get_document(key="3") - - with pytest.raises(HttpResponseError): - await client.get_document(key="4") - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_delete_documents_missing( - self, api_key, endpoint, index_name, **kwargs - ): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - async with client: - results = await client.delete_documents( - [{"hotelId": "1000"}, {"hotelId": "4"}] - ) - assert len(results) == 2 - assert set(x.status_code for x in results) == {200} - - # There can be some lag before a document is searchable - if self.is_live: - time.sleep(TIME_TO_SLEEP) - - assert await client.get_document_count() == 9 - - with pytest.raises(HttpResponseError): - await client.get_document(key="1000") - - with pytest.raises(HttpResponseError): - await client.get_document(key="4") - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_merge_documents_existing( - self, api_key, endpoint, index_name, **kwargs - ): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - async with client: - results = await client.merge_documents( - [{"hotelId": "3", "rating": 1}, {"hotelId": "4", "rating": 2}] - ) - assert len(results) == 2 - assert set(x.status_code for x in results) == {200} - - # There can be some lag before a document is searchable - if self.is_live: - time.sleep(TIME_TO_SLEEP) - - assert await client.get_document_count() == 10 - - result = await client.get_document(key="3") - assert result["rating"] == 1 - - result = await client.get_document(key="4") - assert result["rating"] == 2 - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_merge_documents_missing( - self, api_key, endpoint, index_name, **kwargs - ): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - async with client: - results = await client.merge_documents( - [{"hotelId": "1000", "rating": 1}, {"hotelId": "4", "rating": 2}] - ) - assert len(results) == 2 - assert set(x.status_code for x in results) == {200, 404} - - # There can be some lag before a document is searchable - if self.is_live: - time.sleep(TIME_TO_SLEEP) - - assert await client.get_document_count() == 10 - - with pytest.raises(HttpResponseError): - await client.get_document(key="1000") - - result = await client.get_document(key="4") - assert result["rating"] == 2 - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_merge_or_upload_documents( - self, api_key, endpoint, index_name, **kwargs - ): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - async with client: - results = await client.merge_or_upload_documents( - [{"hotelId": "1000", "rating": 1}, {"hotelId": "4", "rating": 2}] - ) - assert len(results) == 2 - assert set(x.status_code for x in results) == {200, 201} - - # There can be some lag before a document is searchable - if self.is_live: - time.sleep(TIME_TO_SLEEP) - - assert await client.get_document_count() == 11 - - result = await client.get_document(key="1000") - assert result["rating"] == 1 - - result = await client.get_document(key="4") - assert result["rating"] == 2 + results = await client.upload_documents(docs) + assert len(results) == len(docs) + doc_count += 1 + assert set(x.status_code for x in results) == {200, 201} + return doc_count + + async def _test_delete_documents_existing(self, client, doc_count): + docs = [{"hotelId": "3"}, {"hotelId": "4"}] + results = await client.delete_documents(docs) + assert len(results) == len(docs) + assert set(x.status_code for x in results) == {200} + doc_count -= len(docs) + + # There can be some lag before a document is searchable + if self.is_live: + time.sleep(TIME_TO_SLEEP) + + assert await client.get_document_count() == doc_count + + with pytest.raises(HttpResponseError): + await client.get_document(key="3") + + with pytest.raises(HttpResponseError): + await client.get_document(key="4") + return doc_count + + async def _test_delete_documents_missing(self, client, doc_count): + # delete one existing and one missing + docs = [{"hotelId": "1003"}, {"hotelId": "2"}] + results = await client.delete_documents(docs) + assert len(results) == len(docs) + assert set(x.status_code for x in results) == {200} + doc_count -= 1 + + # There can be some lag before a document is searchable + if self.is_live: + time.sleep(TIME_TO_SLEEP) + + assert await client.get_document_count() == doc_count + + with pytest.raises(HttpResponseError): + await client.get_document(key="1003") + + with pytest.raises(HttpResponseError): + await client.get_document(key="2") + return doc_count + + async def _test_merge_documents_existing(self, client, doc_count): + docs = [{"hotelId": "5", "rating": 1}, {"hotelId": "6", "rating": 2}] + results = await client.merge_documents(docs) + assert len(results) == len(docs) + assert set(x.status_code for x in results) == {200} + + # There can be some lag before a document is searchable + if self.is_live: + time.sleep(TIME_TO_SLEEP) + + assert await client.get_document_count() == doc_count + + result = await client.get_document(key="5") + assert result["rating"] == 1 + + result = await client.get_document(key="6") + assert result["rating"] == 2 + return doc_count + + async def _test_merge_documents_missing(self, client, doc_count): + # merge to one existing and one missing document + docs = [{"hotelId": "1003", "rating": 1}, {"hotelId": "1", "rating": 2}] + results = await client.merge_documents(docs) + assert len(results) == len(docs) + assert set(x.status_code for x in results) == {200, 404} + + # There can be some lag before a document is searchable + if self.is_live: + time.sleep(TIME_TO_SLEEP) + + assert await client.get_document_count() == doc_count + + with pytest.raises(HttpResponseError): + await client.get_document(key="1003") + + result = await client.get_document(key="1") + assert result["rating"] == 2 + return doc_count + + async def _test_merge_or_upload_documents(self, client, doc_count): + # merge to one existing and one missing + docs = [{"hotelId": "1003", "rating": 1}, {"hotelId": "1", "rating": 2}] + results = await client.merge_or_upload_documents(docs) + assert len(results) == len(docs) + assert set(x.status_code for x in results) == {200, 201} + doc_count += 1 + + # There can be some lag before a document is searchable + if self.is_live: + time.sleep(TIME_TO_SLEEP) + + assert await client.get_document_count() == doc_count + + result = await client.get_document(key="1003") + assert result["rating"] == 1 + + result = await client.get_document(key="1") + assert result["rating"] == 2 + return doc_count diff --git a/sdk/search/azure-search-documents/tests/async_tests/test_search_client_search_live_async.py b/sdk/search/azure-search-documents/tests/async_tests/test_search_client_search_live_async.py index 2f65d27d0477..1aa3bb4ec671 100644 --- a/sdk/search/azure-search-documents/tests/async_tests/test_search_client_search_live_async.py +++ b/sdk/search/azure-search-documents/tests/async_tests/test_search_client_search_live_async.py @@ -3,158 +3,111 @@ # Licensed under the MIT License. See License.txt in the project root for # license information. # -------------------------------------------------------------------------- -import asyncio -import functools -import json -from os.path import dirname, join, realpath +import pytest -from devtools_testutils import AzureMgmtTestCase, ResourceGroupPreparer -from azure_devtools.scenario_tests.utilities import trim_kwargs_from_test_function -from azure_devtools.scenario_tests import ReplayableTest - -from search_service_preparer import SearchServicePreparer - -CWD = dirname(realpath(__file__)) - -SCHEMA = open(join(CWD, "..", "hotel_schema.json")).read() -BATCH = json.load(open(join(CWD, "..", "hotel_small.json"), encoding='utf-8')) - -from azure.core.credentials import AzureKeyCredential +from azure.core.exceptions import HttpResponseError from azure.search.documents.aio import SearchClient +from devtools_testutils.aio import recorded_by_proxy_async +from devtools_testutils import AzureRecordedTestCase -TIME_TO_SLEEP = 3 +from search_service_preparer import SearchEnvVarPreparer, search_decorator -def await_prepared_test(test_fn): - """Synchronous wrapper for async test methods. Used to avoid making changes - upstream to AbstractPreparer (which doesn't await the functions it wraps) - """ - @functools.wraps(test_fn) - def run(test_class_instance, *args, **kwargs): - trim_kwargs_from_test_function(test_fn, kwargs) - loop = asyncio.get_event_loop() - return loop.run_until_complete(test_fn(test_class_instance, **kwargs)) +class TestClientTestAsync(AzureRecordedTestCase): - return run - - -class SearchClientTestAsync(AzureMgmtTestCase): - FILTER_HEADERS = ReplayableTest.FILTER_HEADERS + ['api-key'] - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_search_simple(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy_async + async def test_search_client(self, endpoint, api_key, index_name): + client = SearchClient(endpoint, index_name, api_key) async with client: - results = [] - async for x in await client.search(search_text="hotel"): - results.append(x) - assert len(results) == 7 - - results = [] - async for x in await client.search(search_text="motel"): - results.append(x) - assert len(results) == 2 - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_search_simple_with_top(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - async with client: - results = [] - async for x in await client.search(search_text="hotel", top=3): - results.append(x) - assert len(results) == 3 - - results = [] - async for x in await client.search(search_text="motel", top=3): - results.append(x) - assert len(results) == 2 - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_search_filter(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - - async with client: - results = [] - select = ["hotelName", "category", "description"] - async for x in await client.search( - search_text="WiFi", - filter="category eq 'Budget'", - select=",".join(select), - order_by="hotelName desc" - ): - results.append(x) - assert [x["hotelName"] for x in results] == sorted( - [x["hotelName"] for x in results], reverse=True - ) - expected = { - "category", - "hotelName", - "description", - "@search.score", - "@search.highlights", - } - assert all(set(x) == expected for x in results) - assert all(x["category"] == "Budget" for x in results) - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_search_filter_array(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) + await self._test_get_search_simple(client) + await self._test_get_search_simple_with_top(client) + await self._test_get_search_filter(client) + await self._test_get_search_filter_array(client) + await self._test_get_search_counts(client) + await self._test_get_search_coverage(client) + await self._test_get_search_facets_none(client) + await self._test_get_search_facets_result(client) + await self._test_autocomplete(client) + await self._test_suggest(client) + + async def _test_get_search_simple(self, client): + results = [] + async for x in await client.search(search_text="hotel"): + results.append(x) + assert len(results) == 7 + + results = [] + async for x in await client.search(search_text="motel"): + results.append(x) + assert len(results) == 2 + + async def _test_get_search_simple_with_top(self, client): + results = [] + async for x in await client.search(search_text="hotel", top=3): + results.append(x) + assert len(results) == 3 + + results = [] + async for x in await client.search(search_text="motel", top=3): + results.append(x) + assert len(results) == 2 + + async def _test_get_search_filter(self, client): + results = [] + select = ["hotelName", "category", "description"] + async for x in await client.search( + search_text="WiFi", + filter="category eq 'Budget'", + select=",".join(select), + order_by="hotelName desc" + ): + results.append(x) + assert [x["hotelName"] for x in results] == sorted( + [x["hotelName"] for x in results], reverse=True ) - - async with client: - results = [] - select = ["hotelName", "category", "description"] - async for x in await client.search( - search_text="WiFi", - filter="category eq 'Budget'", - select=select, - order_by="hotelName desc" - ): - results.append(x) - assert [x["hotelName"] for x in results] == sorted( - [x["hotelName"] for x in results], reverse=True - ) - expected = { - "category", - "hotelName", - "description", - "@search.score", - "@search.highlights", - } - assert all(set(x) == expected for x in results) - assert all(x["category"] == "Budget" for x in results) - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_search_counts(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) + expected = { + "category", + "hotelName", + "description", + "@search.score", + "@search.highlights", + } + assert all(set(x) == expected for x in results) + assert all(x["category"] == "Budget" for x in results) + + async def _test_get_search_filter_array(self, client): + results = [] + select = ["hotelName", "category", "description"] + async for x in await client.search( + search_text="WiFi", + filter="category eq 'Budget'", + select=select, + order_by="hotelName desc" + ): + results.append(x) + assert [x["hotelName"] for x in results] == sorted( + [x["hotelName"] for x in results], reverse=True ) - + expected = { + "category", + "hotelName", + "description", + "@search.score", + "@search.highlights", + } + assert all(set(x) == expected for x in results) + assert all(x["category"] == "Budget" for x in results) + + async def _test_get_search_counts(self, client): results = await client.search(search_text="hotel") assert await results.get_count() is None results = await client.search(search_text="hotel", include_total_count=True) assert await results.get_count() == 7 - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_search_coverage(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - + async def _test_get_search_coverage(self, client): results = await client.search(search_text="hotel") assert await results.get_coverage() is None @@ -163,65 +116,35 @@ async def test_get_search_coverage(self, api_key, endpoint, index_name, **kwargs assert isinstance(cov, float) assert cov >= 50.0 - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_search_facets_none( - self, api_key, endpoint, index_name, **kwargs - ): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) + async def _test_get_search_facets_none(self, client): + select = ("hotelName", "category", "description") + results = await client.search( + search_text="WiFi", + select=",".join(select) ) - - async with client: - select = ("hotelName", "category", "description") - results = await client.search( - search_text="WiFi", - select=",".join(select) - ) - assert await results.get_facets() is None - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_search_facets_result( - self, api_key, endpoint, index_name, **kwargs - ): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) + assert await results.get_facets() is None + + async def _test_get_search_facets_result(self, client): + select = ("hotelName", "category", "description") + results = await client.search( + search_text="WiFi", + facets=["category"], + select=",".join(select) ) - - async with client: - select = ("hotelName", "category", "description") - results = await client.search( - search_text="WiFi", - facets=["category"], - select=",".join(select) - ) - assert await results.get_facets() == { - "category": [ - {"value": "Budget", "count": 4}, - {"value": "Luxury", "count": 1}, - ] - } - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_autocomplete(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - async with client: - results = await client.autocomplete(search_text="mot", suggester_name="sg") - assert results == [{"text": "motel", "query_plus_text": "motel"}] - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_suggest(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - async with client: - results = await client.suggest(search_text="mot", suggester_name="sg") - assert results == [ - {"hotelId": "2", "text": "Cheapest hotel in town. Infact, a motel."}, - {"hotelId": "9", "text": "Secret Point Motel"}, + assert await results.get_facets() == { + "category": [ + {"value": "Budget", "count": 4}, + {"value": "Luxury", "count": 1}, ] + } + + async def _test_autocomplete(self, client): + results = await client.autocomplete(search_text="mot", suggester_name="sg") + assert results == [{"text": "motel", "query_plus_text": "motel"}] + + async def _test_suggest(self, client): + results = await client.suggest(search_text="mot", suggester_name="sg") + assert results == [ + {"hotelId": "2", "text": "Cheapest hotel in town. Infact, a motel."}, + {"hotelId": "9", "text": "Secret Point Motel"}, + ] diff --git a/sdk/search/azure-search-documents/tests/async_tests/test_search_index_client_data_source_live_async.py b/sdk/search/azure-search-documents/tests/async_tests/test_search_index_client_data_source_live_async.py index 784386ba90f6..0b6cce0b6083 100644 --- a/sdk/search/azure-search-documents/tests/async_tests/test_search_index_client_data_source_live_async.py +++ b/sdk/search/azure-search-documents/tests/async_tests/test_search_index_client_data_source_live_async.py @@ -3,118 +3,94 @@ # Licensed under the MIT License. See License.txt in the project root for # license information. # -------------------------------------------------------------------------- -import asyncio -import functools -import json -from os.path import dirname, join, realpath import pytest from azure.core import MatchConditions -from azure.core.credentials import AzureKeyCredential -from devtools_testutils import AzureMgmtTestCase - -from azure_devtools.scenario_tests import ReplayableTest -from azure_devtools.scenario_tests.utilities import trim_kwargs_from_test_function - -from search_service_preparer import SearchServicePreparer, SearchResourceGroupPreparer - from azure.core.exceptions import HttpResponseError +from devtools_testutils.aio import recorded_by_proxy_async +from devtools_testutils import AzureRecordedTestCase + +from search_service_preparer import SearchEnvVarPreparer, search_decorator from azure.search.documents.indexes.models import( SearchIndexerDataSourceConnection, SearchIndexerDataContainer, ) from azure.search.documents.indexes.aio import SearchIndexerClient -CWD = dirname(realpath(__file__)) -SCHEMA = open(join(CWD, "..", "hotel_schema.json")).read() -BATCH = json.load(open(join(CWD, "..", "hotel_small.json"), encoding='utf-8')) -TIME_TO_SLEEP = 5 - -def await_prepared_test(test_fn): - """Synchronous wrapper for async test methods. Used to avoid making changes - upstream to AbstractPreparer (which doesn't await the functions it wraps) - """ - @functools.wraps(test_fn) - def run(test_class_instance, *args, **kwargs): - trim_kwargs_from_test_function(test_fn, kwargs) - loop = asyncio.get_event_loop() - return loop.run_until_complete(test_fn(test_class_instance, **kwargs)) +class TestSearchClientDataSourcesAsync(AzureRecordedTestCase): - return run - -class SearchDataSourcesClientTest(AzureMgmtTestCase): - FILTER_HEADERS = ReplayableTest.FILTER_HEADERS + ['api-key'] - - def _create_data_source_connection(self, name="sample-datasource"): + def _create_data_source_connection(self, cs, name): container = SearchIndexerDataContainer(name='searchcontainer') data_source_connection = SearchIndexerDataSourceConnection( name=name, type="azureblob", - connection_string=self.settings.AZURE_STORAGE_CONNECTION_STRING, + connection_string=cs, container=container ) return data_source_connection - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_create_datasource_async(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - data_source_connection = self._create_data_source_connection() + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy_async + async def test_data_source(self, endpoint, api_key, **kwargs): + storage_cs = kwargs.get("search_storage_connection_string") + client = SearchIndexerClient(endpoint, api_key) + async with client: + await self._test_create_datasource(client, storage_cs) + await self._test_delete_datasource(client, storage_cs) + await self._test_get_datasource(client, storage_cs) + await self._test_list_datasources(client, storage_cs) + await self._test_create_or_update_datasource(client, storage_cs) + await self._test_create_or_update_datasource_if_unchanged(client, storage_cs) + await self._test_delete_datasource_if_unchanged(client, storage_cs) + + async def _test_create_datasource(self, client, storage_cs): + ds_name = "create" + data_source_connection = self._create_data_source_connection(storage_cs, ds_name) result = await client.create_data_source_connection(data_source_connection) - assert result.name == "sample-datasource" + assert result.name == ds_name assert result.type == "azureblob" - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_delete_datasource_async(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - data_source_connection = self._create_data_source_connection() - result = await client.create_data_source_connection(data_source_connection) - assert len(await client.get_data_source_connections()) == 1 - await client.delete_data_source_connection("sample-datasource") - assert len(await client.get_data_source_connections()) == 0 - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_datasource_async(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - data_source_connection = self._create_data_source_connection() - created = await client.create_data_source_connection(data_source_connection) - result = await client.get_data_source_connection("sample-datasource") - assert result.name == "sample-datasource" - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_list_datasource_async(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - data_source_connection1 = self._create_data_source_connection() - data_source_connection2 = self._create_data_source_connection(name="another-sample") - created1 = await client.create_data_source_connection(data_source_connection1) - created2 = await client.create_data_source_connection(data_source_connection2) + async def _test_delete_datasource(self, client, storage_cs): + ds_name = "delete" + data_source_connection = self._create_data_source_connection(storage_cs, ds_name) + await client.create_data_source_connection(data_source_connection) + expected_count = len(await client.get_data_source_connections()) - 1 + await client.delete_data_source_connection(ds_name) + assert len(await client.get_data_source_connections()) == expected_count + + async def _test_get_datasource(self, client, storage_cs): + ds_name = "get" + data_source_connection = self._create_data_source_connection(storage_cs, ds_name) + await client.create_data_source_connection(data_source_connection) + result = await client.get_data_source_connection(ds_name) + assert result.name == ds_name + + async def _test_list_datasources(self, client, storage_cs): + data_source_connection1 = self._create_data_source_connection(storage_cs, "list") + data_source_connection2 = self._create_data_source_connection(storage_cs, "list2") + await client.create_data_source_connection(data_source_connection1) + await client.create_data_source_connection(data_source_connection2) result = await client.get_data_source_connections() assert isinstance(result, list) - assert set(x.name for x in result) == {"sample-datasource", "another-sample"} + assert set(x.name for x in result).intersection(set(["list", "list2"])) == set(["list", "list2"]) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_create_or_update_datasource_async(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - data_source_connection = self._create_data_source_connection() - created = await client.create_data_source_connection(data_source_connection) - assert len(await client.get_data_source_connections()) == 1 + async def _test_create_or_update_datasource(self, client, storage_cs): + ds_name = "cou" + data_source_connection = self._create_data_source_connection(storage_cs, ds_name) + await client.create_data_source_connection(data_source_connection) + expected_count = len(await client.get_data_source_connections()) data_source_connection.description = "updated" await client.create_or_update_data_source_connection(data_source_connection) - assert len(await client.get_data_source_connections()) == 1 - result = await client.get_data_source_connection("sample-datasource") - assert result.name == "sample-datasource" + assert len(await client.get_data_source_connections()) == expected_count + result = await client.get_data_source_connection(ds_name) + assert result.name == ds_name assert result.description == "updated" - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_create_or_update_datasource_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - data_source_connection = self._create_data_source_connection() + async def _test_create_or_update_datasource_if_unchanged(self, client, storage_cs): + ds_name = "couunch" + data_source_connection = self._create_data_source_connection(storage_cs, ds_name) created = await client.create_data_source_connection(data_source_connection) etag = created.e_tag @@ -127,13 +103,10 @@ async def test_create_or_update_datasource_if_unchanged(self, api_key, endpoint, data_source_connection.description = "changed" with pytest.raises(HttpResponseError): await client.create_or_update_data_source_connection(data_source_connection, match_condition=MatchConditions.IfNotModified) - assert len(await client.get_data_source_connections()) == 1 - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_delete_datasource_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - data_source_connection = self._create_data_source_connection() + async def _test_delete_datasource_if_unchanged(self, client, storage_cs): + ds_name = "delunch" + data_source_connection = self._create_data_source_connection(storage_cs, ds_name) created = await client.create_data_source_connection(data_source_connection) etag = created.e_tag @@ -145,4 +118,3 @@ async def test_delete_datasource_if_unchanged(self, api_key, endpoint, index_nam data_source_connection.e_tag = etag # reset to the original data source connection with pytest.raises(HttpResponseError): await client.delete_data_source_connection(data_source_connection, match_condition=MatchConditions.IfNotModified) - assert len(await client.get_data_source_connections()) == 1 diff --git a/sdk/search/azure-search-documents/tests/async_tests/test_search_index_client_live_async.py b/sdk/search/azure-search-documents/tests/async_tests/test_search_index_client_live_async.py index 404d20110e85..e41af33bfcd1 100644 --- a/sdk/search/azure-search-documents/tests/async_tests/test_search_index_client_live_async.py +++ b/sdk/search/azure-search-documents/tests/async_tests/test_search_index_client_live_async.py @@ -3,22 +3,15 @@ # Licensed under the MIT License. See License.txt in the project root for # license information. # -------------------------------------------------------------------------- -import asyncio -import functools -import json -from os.path import dirname, join, realpath - import pytest -from azure.core import MatchConditions -from azure.core.credentials import AzureKeyCredential -from devtools_testutils import AzureMgmtTestCase - -from azure_devtools.scenario_tests import ReplayableTest -from azure_devtools.scenario_tests.utilities import trim_kwargs_from_test_function - -from search_service_preparer import SearchServicePreparer, SearchResourceGroupPreparer from azure.core.exceptions import HttpResponseError +from azure.core import MatchConditions +from devtools_testutils.aio import recorded_by_proxy_async +from devtools_testutils import AzureRecordedTestCase + +from search_service_preparer import SearchEnvVarPreparer, search_decorator +from azure.search.documents.indexes.aio import SearchIndexClient from azure.search.documents.indexes.models import( AnalyzeTextOptions, CorsOptions, @@ -27,91 +20,79 @@ SimpleField, SearchFieldDataType ) -from azure.search.documents.indexes.aio import SearchIndexClient - -CWD = dirname(realpath(__file__)) -SCHEMA = open(join(CWD, "..", "hotel_schema.json")).read() -BATCH = json.load(open(join(CWD, "..", "hotel_small.json"), encoding='utf-8')) -TIME_TO_SLEEP = 5 -def await_prepared_test(test_fn): - """Synchronous wrapper for async test methods. Used to avoid making changes - upstream to AbstractPreparer (which doesn't await the functions it wraps) - """ - - @functools.wraps(test_fn) - def run(test_class_instance, *args, **kwargs): - trim_kwargs_from_test_function(test_fn, kwargs) - loop = asyncio.get_event_loop() - return loop.run_until_complete(test_fn(test_class_instance, **kwargs)) - - return run - -class SearchIndexClientTest(AzureMgmtTestCase): - FILTER_HEADERS = ReplayableTest.FILTER_HEADERS + ['api-key'] - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer() - async def test_get_service_statistics(self, api_key, endpoint, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) +class TestSearchIndexClientAsync(AzureRecordedTestCase): + + @SearchEnvVarPreparer() + @search_decorator(schema=None, index_batch=None) + @recorded_by_proxy_async + async def test_search_index_client(self, api_key, endpoint, index_name): + client = SearchIndexClient(endpoint, api_key) + index_name = "hotels" + async with client: + await self._test_get_service_statistics(client) + await self._test_list_indexes_empty(client) + await self._test_create_index(client, index_name) + await self._test_list_indexes(client, index_name) + await self._test_get_index(client, index_name) + await self._test_get_index_statistics(client, index_name) + await self._test_delete_indexes_if_unchanged(client) + await self._test_create_or_update_index(client) + await self._test_create_or_update_indexes_if_unchanged(client) + await self._test_analyze_text(client, index_name) + await self._test_delete_indexes(client) + + async def _test_get_service_statistics(self, client): result = await client.get_service_statistics() assert isinstance(result, dict) assert set(result.keys()) == {"counters", "limits"} - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer() - async def test_list_indexes_empty(self, api_key, endpoint, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + async def _test_list_indexes_empty(self, client): result = client.list_indexes() - with pytest.raises(StopAsyncIteration): await result.__anext__() - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_list_indexes(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) - result = client.list_indexes() + async def _test_create_index(self, client, index_name): + fields = fields = [ + SimpleField(name="hotelId", type=SearchFieldDataType.String, key=True), + SimpleField(name="baseRate", type=SearchFieldDataType.Double) + ] + scoring_profile = ScoringProfile( + name="MyProfile" + ) + scoring_profiles = [] + scoring_profiles.append(scoring_profile) + cors_options = CorsOptions(allowed_origins=["*"], max_age_in_seconds=60) + index = SearchIndex( + name=index_name, + fields=fields, + scoring_profiles=scoring_profiles, + cors_options=cors_options) + result = await client.create_index(index) + assert result.name == "hotels" + assert result.scoring_profiles[0].name == scoring_profile.name + assert result.cors_options.allowed_origins == cors_options.allowed_origins + assert result.cors_options.max_age_in_seconds == cors_options.max_age_in_seconds + + async def _test_list_indexes(self, client, index_name): + result = client.list_indexes() first = await result.__anext__() assert first.name == index_name - with pytest.raises(StopAsyncIteration): await result.__anext__() - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_index(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + async def _test_get_index(self, client, index_name): result = await client.get_index(index_name) assert result.name == index_name - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_index_statistics(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + async def _test_get_index_statistics(self, client, index_name): result = await client.get_index_statistics(index_name) assert set(result.keys()) == {'document_count', 'storage_size'} - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_delete_indexes(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) - await client.delete_index(index_name) - import time - if self.is_live: - time.sleep(TIME_TO_SLEEP) - result = client.list_indexes() - with pytest.raises(StopAsyncIteration): - await result.__anext__() - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_delete_indexes_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) - + async def _test_delete_indexes_if_unchanged(self, client): # First create an index - name = "hotels" + name = "hotels-del-unchanged" fields = [ { "name": "hotelId", @@ -136,7 +117,7 @@ async def test_delete_indexes_if_unchanged(self, api_key, endpoint, index_name, cors_options=cors_options) result = await client.create_index(index) etag = result.e_tag - # get e tag nd update + # get eTag and update index.scoring_profiles = [] await client.create_or_update_index(index) @@ -144,37 +125,8 @@ async def test_delete_indexes_if_unchanged(self, api_key, endpoint, index_name, with pytest.raises(HttpResponseError): await client.delete_index(index, match_condition=MatchConditions.IfNotModified) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_create_index(self, api_key, endpoint, index_name, **kwargs): - name = "hotels" - fields = fields = [ - SimpleField(name="hotelId", type=SearchFieldDataType.String, key=True), - SimpleField(name="baseRate", type=SearchFieldDataType.Double) - ] - - scoring_profile = ScoringProfile( - name="MyProfile" - ) - scoring_profiles = [] - scoring_profiles.append(scoring_profile) - cors_options = CorsOptions(allowed_origins=["*"], max_age_in_seconds=60) - index = SearchIndex( - name=name, - fields=fields, - scoring_profiles=scoring_profiles, - cors_options=cors_options) - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) - result = await client.create_index(index) - assert result.name == "hotels" - assert result.scoring_profiles[0].name == scoring_profile.name - assert result.cors_options.allowed_origins == cors_options.allowed_origins - assert result.cors_options.max_age_in_seconds == cors_options.max_age_in_seconds - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_create_or_update_index(self, api_key, endpoint, index_name, **kwargs): - name = "hotels" + async def _test_create_or_update_index(self, client): + name = "hotels-cou" fields = fields = [ SimpleField(name="hotelId", type=SearchFieldDataType.String, key=True), SimpleField(name="baseRate", type=SearchFieldDataType.Double) @@ -187,7 +139,6 @@ async def test_create_or_update_index(self, api_key, endpoint, index_name, **kwa fields=fields, scoring_profiles=scoring_profiles, cors_options=cors_options) - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) result = await client.create_or_update_index(index=index) assert len(result.scoring_profiles) == 0 assert result.cors_options.allowed_origins == cors_options.allowed_origins @@ -207,13 +158,9 @@ async def test_create_or_update_index(self, api_key, endpoint, index_name, **kwa assert result.cors_options.allowed_origins == cors_options.allowed_origins assert result.cors_options.max_age_in_seconds == cors_options.max_age_in_seconds - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_create_or_update_indexes_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) - + async def _test_create_or_update_indexes_if_unchanged(self, client): # First create an index - name = "hotels" + name = "hotels-coa-unchanged" fields = [ { "name": "hotelId", @@ -238,7 +185,7 @@ async def test_create_or_update_indexes_if_unchanged(self, api_key, endpoint, in cors_options=cors_options) result = await client.create_index(index) etag = result.e_tag - # get e tag nd update + # get eTag and update index.scoring_profiles = [] await client.create_or_update_index(index) @@ -246,10 +193,12 @@ async def test_create_or_update_indexes_if_unchanged(self, api_key, endpoint, in with pytest.raises(HttpResponseError): await client.create_or_update_index(index, match_condition=MatchConditions.IfNotModified) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_analyze_text(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + async def _test_analyze_text(self, client, index_name): analyze_request = AnalyzeTextOptions(text="One's ", analyzer_name="standard.lucene") result = await client.analyze_text(index_name, analyze_request) assert len(result.tokens) == 2 + + async def _test_delete_indexes(self, client): + result = client.list_indexes() + async for index in result: + await client.delete_index(index.name) diff --git a/sdk/search/azure-search-documents/tests/async_tests/test_search_index_client_skillset_live_async.py b/sdk/search/azure-search-documents/tests/async_tests/test_search_index_client_skillset_live_async.py index 62822e042f33..67936027a208 100644 --- a/sdk/search/azure-search-documents/tests/async_tests/test_search_index_client_skillset_live_async.py +++ b/sdk/search/azure-search-documents/tests/async_tests/test_search_index_client_skillset_live_async.py @@ -3,23 +3,13 @@ # Licensed under the MIT License. See License.txt in the project root for # license information. # -------------------------------------------------------------------------- -import asyncio -import functools -import json -from os.path import dirname, join, realpath -import time import pytest from azure.core import MatchConditions -from azure.core.credentials import AzureKeyCredential -from devtools_testutils import AzureMgmtTestCase - -from azure_devtools.scenario_tests import ReplayableTest -from azure_devtools.scenario_tests.utilities import trim_kwargs_from_test_function - -from search_service_preparer import SearchServicePreparer, SearchResourceGroupPreparer - from azure.core.exceptions import HttpResponseError +from devtools_testutils.aio import recorded_by_proxy_async +from devtools_testutils import AzureRecordedTestCase +from search_service_preparer import SearchEnvVarPreparer, search_decorator from azure.search.documents.indexes.models import( EntityLinkingSkill, EntityRecognitionSkill, @@ -32,33 +22,29 @@ ) from azure.search.documents.indexes.aio import SearchIndexerClient -CWD = dirname(realpath(__file__)) -SCHEMA = open(join(CWD, "..", "hotel_schema.json")).read() -BATCH = json.load(open(join(CWD, "..", "hotel_small.json"), encoding='utf-8')) -TIME_TO_SLEEP = 5 - -def await_prepared_test(test_fn): - """Synchronous wrapper for async test methods. Used to avoid making changes - upstream to AbstractPreparer (which doesn't await the functions it wraps) - """ - - @functools.wraps(test_fn) - def run(test_class_instance, *args, **kwargs): - trim_kwargs_from_test_function(test_fn, kwargs) - loop = asyncio.get_event_loop() - return loop.run_until_complete(test_fn(test_class_instance, **kwargs)) - - return run - -class SearchSkillsetClientTest(AzureMgmtTestCase): - FILTER_HEADERS = ReplayableTest.FILTER_HEADERS + ['api-key'] - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_create_skillset(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - name = "test-ss" +class TestSearchClientSkillsets(AzureRecordedTestCase): + + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy_async + async def test_skillset_crud(self, api_key, endpoint): + client = SearchIndexerClient(endpoint, api_key) + async with client: + await self._test_create_skillset(client) + await self._test_get_skillset(client) + await self._test_get_skillsets(client) + # TODO: Disabled due to service regression. See #22769 + #await self._test_create_or_update_skillset(client) + await self._test_create_or_update_skillset_if_unchanged(client) + # TODO: Disabled due to service regression. See #22769 + #await self._test_create_or_update_skillset_inplace(client) + # TODO: Disabled due to service regression. See #22769 + #await self._test_delete_skillset_if_unchanged(client) + await self._test_delete_skillset(client) + + async def _test_create_skillset(self, client): + name = "test-ss-create" s1 = EntityRecognitionSkill(name="skill1", inputs=[InputFieldMappingEntry(name="text", source="/document/content")], outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizationsS1")], @@ -96,7 +82,7 @@ async def test_create_skillset(self, api_key, endpoint, index_name, **kwargs): result = await client.create_skillset(skillset) assert isinstance(result, SearchIndexerSkillset) - assert result.name == "test-ss" + assert result.name == name assert result.description == "desc" assert result.e_tag assert len(result.skills) == 5 @@ -112,125 +98,102 @@ async def test_create_skillset(self, api_key, endpoint, index_name, **kwargs): assert result.skills[4].minimum_precision == 0.5 assert len(await client.get_skillsets()) == 1 - await client.reset_skills(result, [x.name for x in result.skills]) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_delete_skillset(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - s = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], - outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizations")]) - - skillset = SearchIndexerSkillset(name='test-ss', skills=list([s]), description="desc") - result = await client.create_skillset(skillset) - assert len(await client.get_skillsets()) == 1 - - await client.delete_skillset("test-ss") - if self.is_live: - time.sleep(TIME_TO_SLEEP) - assert len(await client.get_skillsets()) == 0 - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_delete_skillset_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - s = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], - outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizations")]) - - skillset = SearchIndexerSkillset(name='test-ss', skills=list([s]), description="desc") - result = await client.create_skillset(skillset) - etag = result.e_tag - - skillset1 = SearchIndexerSkillset(name='test-ss', skills=list([s]), description="updated") - updated = await client.create_or_update_skillset(skillset1) - updated.e_tag = etag - - with pytest.raises(HttpResponseError): - await client.delete_skillset(updated, match_condition=MatchConditions.IfNotModified) - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_skillset(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) + async def _test_get_skillset(self, client): + name = "test-ss-get" s = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizations")]) - - skillset = SearchIndexerSkillset(name='test-ss', skills=list([s]), description="desc") + skillset = SearchIndexerSkillset(name=name, skills=list([s]), description="desc") await client.create_skillset(skillset) - assert len(await client.get_skillsets()) == 1 - - result = await client.get_skillset("test-ss") + result = await client.get_skillset(name) assert isinstance(result, SearchIndexerSkillset) - assert result.name == "test-ss" + assert result.name == name assert result.description == "desc" assert result.e_tag assert len(result.skills) == 1 assert isinstance(result.skills[0], EntityRecognitionSkill) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_skillsets(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) + async def _test_get_skillsets(self, client): + name1 = "test-ss-list-1" + name2 = "test-ss-list-2" s = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizations")]) - skillset1 = SearchIndexerSkillset(name='test-ss-1', skills=list([s]), description="desc1") + skillset1 = SearchIndexerSkillset(name=name1, skills=list([s]), description="desc1") await client.create_skillset(skillset1) - skillset2 = SearchIndexerSkillset(name='test-ss-2', skills=list([s]), description="desc2") + skillset2 = SearchIndexerSkillset(name=name2, skills=list([s]), description="desc2") await client.create_skillset(skillset2) result = await client.get_skillsets() assert isinstance(result, list) assert all(isinstance(x, SearchIndexerSkillset) for x in result) - assert set(x.name for x in result) == {"test-ss-1", "test-ss-2"} + assert set(x.name for x in result).intersection([name1, name2]) == set([name1, name2]) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_create_or_update_skillset(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) + async def _test_create_or_update_skillset(self, client): + name = "test-ss-create-or-update" s = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizations")]) - skillset1 = SearchIndexerSkillset(name='test-ss', skills=list([s]), description="desc1") + skillset1 = SearchIndexerSkillset(name=name, skills=list([s]), description="desc1") await client.create_or_update_skillset(skillset1) - skillset2 = SearchIndexerSkillset(name='test-ss', skills=list([s]), description="desc2") + expected_count = len(await client.get_skillsets()) + skillset2 = SearchIndexerSkillset(name=name, skills=list([s]), description="desc2") await client.create_or_update_skillset(skillset2) - assert len(await client.get_skillsets()) == 1 + assert len(await client.get_skillsets()) == expected_count - result = await client.get_skillset("test-ss") + result = await client.get_skillset(name) assert isinstance(result, SearchIndexerSkillset) - assert result.name == "test-ss" + assert result.name == name assert result.description == "desc2" - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_create_or_update_skillset_inplace(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) + async def _test_create_or_update_skillset_inplace(self, client): + name = "test-ss-create-or-update-inplace" s = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizations")]) - skillset1 = SearchIndexerSkillset(name='test-ss', skills=list([s]), description="desc1") + skillset1 = SearchIndexerSkillset(name=name, skills=list([s]), description="desc1") ss = await client.create_or_update_skillset(skillset1) - skillset2 = SearchIndexerSkillset(name='test-ss', skills=[s], description="desc2", skillset=ss) + expected_count = len(await client.get_skillsets()) + skillset2 = SearchIndexerSkillset(name=name, skills=[s], description="desc2", skillset=ss) await client.create_or_update_skillset(skillset2) - assert len(await client.get_skillsets()) == 1 + assert len(await client.get_skillsets()) == expected_count - result = await client.get_skillset("test-ss") + result = await client.get_skillset(name) assert isinstance(result, SearchIndexerSkillset) - assert result.name == "test-ss" + assert result.name == name assert result.description == "desc2" - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_create_or_update_skillset_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) + async def _test_create_or_update_skillset_if_unchanged(self, client): + name = "test-ss-create-or-update-unchanged" s = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizations")]) - skillset1 = SearchIndexerSkillset(name='test-ss', skills=list([s]), description="desc1") + skillset1 = SearchIndexerSkillset(name=name, skills=list([s]), description="desc1") ss = await client.create_or_update_skillset(skillset1) etag = ss.e_tag - skillset2 = SearchIndexerSkillset(name='test-ss', skills=[s], description="desc2", skillset=ss) - await client.create_or_update_skillset(skillset2) - assert len(await client.get_skillsets()) == 1 + updated = SearchIndexerSkillset(name=name, skills=[s], description="desc2", skillset=ss) + updated.e_tag = etag + with pytest.raises(HttpResponseError): + await client.create_or_update_skillset(updated, match_condition=MatchConditions.IfNotModified) + + async def _test_delete_skillset_if_unchanged(self, client): + name = "test-ss-deleted-unchanged" + s = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], + outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizations")]) + + skillset = SearchIndexerSkillset(name=name, skills=list([s]), description="desc") + result = await client.create_skillset(skillset) + etag = result.e_tag + + skillset1 = SearchIndexerSkillset(name=name, skills=list([s]), description="updated") + updated = await client.create_or_update_skillset(skillset1) + updated.e_tag = etag + + with pytest.raises(HttpResponseError): + await client.delete_skillset(updated, match_condition=MatchConditions.IfNotModified) + + async def _test_delete_skillset(self, client): + result = await client.get_skillset_names() + for skillset in result: + await client.delete_skillset(skillset) diff --git a/sdk/search/azure-search-documents/tests/async_tests/test_search_index_client_synonym_map_live_async.py b/sdk/search/azure-search-documents/tests/async_tests/test_search_index_client_synonym_map_live_async.py index 7585acd01701..2810a21767b8 100644 --- a/sdk/search/azure-search-documents/tests/async_tests/test_search_index_client_synonym_map_live_async.py +++ b/sdk/search/azure-search-documents/tests/async_tests/test_search_index_client_synonym_map_live_async.py @@ -3,89 +3,71 @@ # Licensed under the MIT License. See License.txt in the project root for # license information. # -------------------------------------------------------------------------- -import asyncio -import functools -import json -from os.path import dirname, join, realpath import pytest -from azure.core import MatchConditions -from azure.core.credentials import AzureKeyCredential -from devtools_testutils import AzureMgmtTestCase - -from azure_devtools.scenario_tests import ReplayableTest -from azure_devtools.scenario_tests.utilities import trim_kwargs_from_test_function - -from search_service_preparer import SearchServicePreparer, SearchResourceGroupPreparer +from azure.core import MatchConditions from azure.core.exceptions import HttpResponseError -from azure.search.documents.indexes.models import( - SynonymMap, -) from azure.search.documents.indexes.aio import SearchIndexClient - -CWD = dirname(realpath(__file__)) -SCHEMA = open(join(CWD, "..", "hotel_schema.json")).read() -BATCH = json.load(open(join(CWD, "..", "hotel_small.json"), encoding='utf-8')) -TIME_TO_SLEEP = 5 - -def await_prepared_test(test_fn): - """Synchronous wrapper for async test methods. Used to avoid making changes - upstream to AbstractPreparer (which doesn't await the functions it wraps) - """ - - @functools.wraps(test_fn) - def run(test_class_instance, *args, **kwargs): - trim_kwargs_from_test_function(test_fn, kwargs) - loop = asyncio.get_event_loop() - return loop.run_until_complete(test_fn(test_class_instance, **kwargs)) - - return run - -class SearchSynonymMapsClientTest(AzureMgmtTestCase): - FILTER_HEADERS = ReplayableTest.FILTER_HEADERS + ['api-key'] - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_create_synonym_map(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) +from azure.search.documents.indexes.models import SynonymMap +from devtools_testutils.aio import recorded_by_proxy_async +from devtools_testutils import AzureRecordedTestCase + +from search_service_preparer import SearchEnvVarPreparer, search_decorator + + +class TestSearchClientSynonymMaps(AzureRecordedTestCase): + + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy_async + async def test_synonym_map(self, endpoint, api_key): + client = SearchIndexClient(endpoint, api_key) + async with client: + await self._test_create_synonym_map(client) + await self._test_delete_synonym_map(client) + await self._test_delete_synonym_map_if_unchanged(client) + await self._test_get_synonym_map(client) + await self._test_get_synonym_maps(client) + await self._test_create_or_update_synonym_map(client) + + async def _test_create_synonym_map(self, client): + expected = len(await client.get_synonym_maps()) + 1 + name = "synmap-create" synonyms = [ "USA, United States, United States of America", "Washington, Wash. => WA", ] - synonym_map = SynonymMap(name="test-syn-map", synonyms=synonyms) + synonym_map = SynonymMap(name=name, synonyms=synonyms) result = await client.create_synonym_map(synonym_map) assert isinstance(result, SynonymMap) - assert result.name == "test-syn-map" + assert result.name == name assert result.synonyms == [ "USA, United States, United States of America", "Washington, Wash. => WA", ] - assert len(await client.get_synonym_maps()) == 1 + assert len(await client.get_synonym_maps()) == expected + await client.delete_synonym_map(name) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_delete_synonym_map(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + async def _test_delete_synonym_map(self, client): + name = "synmap-del" synonyms = [ "USA, United States, United States of America", "Washington, Wash. => WA", ] - synonym_map = SynonymMap(name="test-syn-map", synonyms=synonyms) + synonym_map = SynonymMap(name=name, synonyms=synonyms) result = await client.create_synonym_map(synonym_map) - assert len(await client.get_synonym_maps()) == 1 - await client.delete_synonym_map("test-syn-map") - assert len(await client.get_synonym_maps()) == 0 + expected = len(await client.get_synonym_maps()) - 1 + await client.delete_synonym_map(name) + assert len(await client.get_synonym_maps()) == expected - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_delete_synonym_map_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + async def _test_delete_synonym_map_if_unchanged(self, client): + name = "synmap-delunch" synonyms = [ "USA, United States, United States of America", "Washington, Wash. => WA", ] - synonym_map = SynonymMap(name="test-syn-map", synonyms=synonyms) + synonym_map = SynonymMap(name=name, synonyms=synonyms) result = await client.create_synonym_map(synonym_map) etag = result.e_tag @@ -97,66 +79,68 @@ async def test_delete_synonym_map_if_unchanged(self, api_key, endpoint, index_na result.e_tag = etag with pytest.raises(HttpResponseError): await client.delete_synonym_map(result, match_condition=MatchConditions.IfNotModified) - assert len(client.get_synonym_maps()) == 1 + await client.delete_synonym_map(name) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_synonym_map(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + async def _test_get_synonym_map(self, client): + expected = len(await client.get_synonym_maps()) + 1 + name = "synmap-get" synonyms = [ "USA, United States, United States of America", "Washington, Wash. => WA", ] - synonym_map = SynonymMap(name="test-syn-map", synonyms=synonyms) + synonym_map = SynonymMap(name=name, synonyms=synonyms) await client.create_synonym_map(synonym_map) - assert len(await client.get_synonym_maps()) == 1 - result = await client.get_synonym_map("test-syn-map") + assert len(await client.get_synonym_maps()) == expected + result = await client.get_synonym_map(name) assert isinstance(result, SynonymMap) - assert result.name == "test-syn-map" + assert result.name == name assert result.synonyms == [ "USA, United States, United States of America", "Washington, Wash. => WA", ] + await client.delete_synonym_map(name) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_synonym_maps(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + async def _test_get_synonym_maps(self, client): + name1 = "synmap-list1" + name2 = "synmap-list2" synonyms = [ "USA, United States, United States of America", "Washington, Wash. => WA", ] - synonym_map_1 = SynonymMap(name="test-syn-map-1", synonyms=synonyms) + synonym_map_1 = SynonymMap(name=name1, synonyms=synonyms) await client.create_synonym_map(synonym_map_1) synonyms = [ "Washington, Wash. => WA", ] - synonym_map_2 = SynonymMap(name="test-syn-map-2", synonyms=synonyms) + synonym_map_2 = SynonymMap(name=name2, synonyms=synonyms) await client.create_synonym_map(synonym_map_2) result = await client.get_synonym_maps() assert isinstance(result, list) assert all(isinstance(x, SynonymMap) for x in result) - assert set(x.name for x in result) == {"test-syn-map-1", "test-syn-map-2"} - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_create_or_update_synonym_map(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + expected = set([name1, name2]) + assert set(x.name for x in result).intersection(expected) == expected + await client.delete_synonym_map(name1) + await client.delete_synonym_map(name2) + + async def _test_create_or_update_synonym_map(self, client): + expected = len(await client.get_synonym_maps()) + 1 + name = "synmap-cou" synonyms = [ "USA, United States, United States of America", "Washington, Wash. => WA", ] - synonym_map = SynonymMap(name="test-syn-map", synonyms=synonyms) + synonym_map = SynonymMap(name=name, synonyms=synonyms) await client.create_synonym_map(synonym_map) - assert len(await client.get_synonym_maps()) == 1 + assert len(await client.get_synonym_maps()) == expected synonym_map.synonyms = [ "Washington, Wash. => WA", ] await client.create_or_update_synonym_map(synonym_map) - assert len(await client.get_synonym_maps()) == 1 - result = await client.get_synonym_map("test-syn-map") + assert len(await client.get_synonym_maps()) == expected + result = await client.get_synonym_map(name) assert isinstance(result, SynonymMap) - assert result.name == "test-syn-map" + assert result.name == name assert result.synonyms == [ "Washington, Wash. => WA", ] + await client.delete_synonym_map(name) diff --git a/sdk/search/azure-search-documents/tests/async_tests/test_search_indexer_client_live_async.py b/sdk/search/azure-search-documents/tests/async_tests/test_search_indexer_client_live_async.py index 0ba36d6d3780..55ef0d7be0f1 100644 --- a/sdk/search/azure-search-documents/tests/async_tests/test_search_indexer_client_live_async.py +++ b/sdk/search/azure-search-documents/tests/async_tests/test_search_indexer_client_live_async.py @@ -3,66 +3,52 @@ # Licensed under the MIT License. See License.txt in the project root for # license information. # -------------------------------------------------------------------------- -import asyncio -import functools -import json -from os.path import dirname, join, realpath -import time import pytest from azure.core import MatchConditions -from azure.core.credentials import AzureKeyCredential -from devtools_testutils import AzureMgmtTestCase - -from azure_devtools.scenario_tests import ReplayableTest -from azure_devtools.scenario_tests.utilities import trim_kwargs_from_test_function - -from search_service_preparer import SearchServicePreparer, SearchResourceGroupPreparer - from azure.core.exceptions import HttpResponseError -from azure.search.documents.indexes.models import( - SearchIndex, - SearchIndexerDataSourceConnection, - SearchIndexerDataContainer, - SearchIndexer, -) from azure.search.documents.indexes.aio import SearchIndexClient, SearchIndexerClient - -CWD = dirname(realpath(__file__)) -SCHEMA = open(join(CWD, "..", "hotel_schema.json")).read() -BATCH = json.load(open(join(CWD, "..", "hotel_small.json"), encoding='utf-8')) -TIME_TO_SLEEP = 5 - -def await_prepared_test(test_fn): - """Synchronous wrapper for async test methods. Used to avoid making changes - upstream to AbstractPreparer (which doesn't await the functions it wraps) - """ - - @functools.wraps(test_fn) - def run(test_class_instance, *args, **kwargs): - trim_kwargs_from_test_function(test_fn, kwargs) - loop = asyncio.get_event_loop() - return loop.run_until_complete(test_fn(test_class_instance, **kwargs)) - - return run - -class SearchIndexersClientTest(AzureMgmtTestCase): - FILTER_HEADERS = ReplayableTest.FILTER_HEADERS + ['api-key'] - - async def _prepare_indexer(self, endpoint, api_key, name="sample-indexer", ds_name="sample-datasource", id_name="hotels"): - con_str = self.settings.AZURE_STORAGE_CONNECTION_STRING - self.scrubber.register_name_pair(con_str, 'connection_string') - container = SearchIndexerDataContainer(name='searchcontainer') +from azure.search.documents.indexes.models import ( + SearchIndex, SearchIndexer, SearchIndexerDataContainer, + SearchIndexerDataSourceConnection) +from devtools_testutils import AzureRecordedTestCase +from devtools_testutils.aio import recorded_by_proxy_async + +from search_service_preparer import SearchEnvVarPreparer, search_decorator + + +class TestSearchIndexerClientTestAsync(AzureRecordedTestCase): + + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy_async + async def test_search_indexers(self, endpoint, api_key, **kwargs): + storage_cs = kwargs.get("search_storage_connection_string") + container_name = kwargs.get("search_storage_container_name") + client = SearchIndexerClient(endpoint, api_key) + index_client = SearchIndexClient(endpoint, api_key) + async with client: + async with index_client: + await self._test_create_indexer(client, index_client, storage_cs, container_name) + await self._test_delete_indexer(client, index_client, storage_cs, container_name) + await self._test_get_indexer(client, index_client, storage_cs, container_name) + await self._test_list_indexer(client, index_client, storage_cs, container_name) + await self._test_create_or_update_indexer(client, index_client, storage_cs, container_name) + await self._test_reset_indexer(client, index_client, storage_cs, container_name) + await self._test_run_indexer(client, index_client, storage_cs, container_name) + await self._test_get_indexer_status(client, index_client, storage_cs, container_name) + await self._test_create_or_update_indexer_if_unchanged(client, index_client, storage_cs, container_name) + await self._test_delete_indexer_if_unchanged(client, index_client, storage_cs, container_name) + + async def _prepare_indexer(self, client, index_client, storage_cs, name, container_name): data_source_connection = SearchIndexerDataSourceConnection( - name=ds_name, + name=f"{name}-ds", type="azureblob", - connection_string=con_str, - container=container + connection_string=storage_cs, + container=SearchIndexerDataContainer(name=container_name) ) - ds_client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - ds = await ds_client.create_data_source_connection(data_source_connection) + ds = await client.create_data_source_connection(data_source_connection) - index_name = id_name fields = [ { "name": "hotelId", @@ -70,105 +56,83 @@ async def _prepare_indexer(self, endpoint, api_key, name="sample-indexer", ds_na "key": True, "searchable": False }] - index = SearchIndex(name=index_name, fields=fields) - ind_client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) - ind = await ind_client.create_index(index) + index = SearchIndex(name=f"{name}-hotels", fields=fields) + ind = await index_client.create_index(index) return SearchIndexer(name=name, data_source_name=ds.name, target_index_name=ind.name) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_create_indexer(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer = await self._prepare_indexer(endpoint, api_key) - result = await client.create_indexer(indexer) - assert result.name == "sample-indexer" - assert result.target_index_name == "hotels" - assert result.data_source_name == "sample-datasource" - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_delete_indexer(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer = await self._prepare_indexer(endpoint, api_key) + async def _test_create_indexer(self, client, index_client, storage_cs, container_name): + name = "create" + indexer = await self._prepare_indexer(client, index_client, storage_cs, name, container_name) result = await client.create_indexer(indexer) - assert len(await client.get_indexers()) == 1 - await client.delete_indexer("sample-indexer") - assert len(await client.get_indexers()) == 0 - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_indexer(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer = await self._prepare_indexer(endpoint, api_key) - created = await client.create_indexer(indexer) - result = await client.get_indexer("sample-indexer") - assert result.name == "sample-indexer" - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_list_indexer(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer1 = await self._prepare_indexer(endpoint, api_key) - indexer2 = await self._prepare_indexer(endpoint, api_key, name="another-indexer", ds_name="another-datasource", id_name="another-index") - created1 = await client.create_indexer(indexer1) - created2 = await client.create_indexer(indexer2) + assert result.name == name + assert result.target_index_name == f"{name}-hotels" + assert result.data_source_name == f"{name}-ds" + + async def _test_delete_indexer(self, client, index_client, storage_cs, container_name): + name = "delete" + indexer = await self._prepare_indexer(client, index_client, storage_cs, name, container_name) + await client.create_indexer(indexer) + expected = len(await client.get_indexers()) - 1 + await client.delete_indexer(name) + assert len(await client.get_indexers()) == expected + + async def _test_get_indexer(self, client, index_client, storage_cs, container_name): + name = "get" + indexer = await self._prepare_indexer(client, index_client, storage_cs, name, container_name) + await client.create_indexer(indexer) + result = await client.get_indexer(name) + assert result.name == name + + async def _test_list_indexer(self, client, index_client, storage_cs, container_name): + name1 = "list1" + name2 = "list2" + indexer1 = await self._prepare_indexer(client, index_client, storage_cs, name1, container_name) + indexer2 = await self._prepare_indexer(client, index_client, storage_cs, name2, container_name) + await client.create_indexer(indexer1) + await client.create_indexer(indexer2) result = await client.get_indexers() assert isinstance(result, list) - assert set(x.name for x in result) == {"sample-indexer", "another-indexer"} + assert set(x.name for x in result).intersection([name1, name2]) == set([name1, name2]) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_create_or_update_indexer(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer = await self._prepare_indexer(endpoint, api_key) - created = await client.create_indexer(indexer) - assert len(await client.get_indexers()) == 1 + async def _test_create_or_update_indexer(self, client, index_client, storage_cs, container_name): + name = "cou" + indexer = await self._prepare_indexer(client, index_client, storage_cs, name, container_name) + await client.create_indexer(indexer) + expected = len(await client.get_indexers()) indexer.description = "updated" await client.create_or_update_indexer(indexer) - assert len(await client.get_indexers()) == 1 - result = await client.get_indexer("sample-indexer") - assert result.name == "sample-indexer" + assert len(await client.get_indexers()) == expected + result = await client.get_indexer(name) + assert result.name == name assert result.description == "updated" - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_reset_indexer(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer = await self._prepare_indexer(endpoint, api_key) - result = await client.create_indexer(indexer) - assert len(await client.get_indexers()) == 1 - await client.reset_indexer("sample-indexer") - assert (await client.get_indexer_status("sample-indexer")).last_result.status.lower() in ('inprogress', 'reset') - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_run_indexer(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer = await self._prepare_indexer(endpoint, api_key) - result = await client.create_indexer(indexer) - assert len(await client.get_indexers()) == 1 - start = time.time() - await client.run_indexer("sample-indexer") - assert (await client.get_indexer_status("sample-indexer")).status == 'running' - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_get_indexer_status(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer = await self._prepare_indexer(endpoint, api_key) - result = await client.create_indexer(indexer) - status = await client.get_indexer_status("sample-indexer") + async def _test_reset_indexer(self, client, index_client, storage_cs, container_name): + name = "reset" + indexer = await self._prepare_indexer(client, index_client, storage_cs, name, container_name) + await client.create_indexer(indexer) + await client.reset_indexer(name) + assert (await client.get_indexer_status(name)).last_result.status.lower() in ('inprogress', 'reset') + + async def _test_run_indexer(self, client, index_client, storage_cs, container_name): + name = "run" + indexer = await self._prepare_indexer(client, index_client, storage_cs, name, container_name) + await client.create_indexer(indexer) + await client.run_indexer(name) + assert (await client.get_indexer_status(name)).status == 'running' + + async def _test_get_indexer_status(self, client, index_client, storage_cs, container_name): + name = "get-status" + indexer = await self._prepare_indexer(client, index_client, storage_cs, name, container_name) + await client.create_indexer(indexer) + status = await client.get_indexer_status(name) assert status.status is not None - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_create_or_update_indexer_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer = await self._prepare_indexer(endpoint, api_key) + async def _test_create_or_update_indexer_if_unchanged(self, client, index_client, storage_cs, container_name): + name = "couunch" + indexer = await self._prepare_indexer(client, index_client, storage_cs, name, container_name) created = await client.create_indexer(indexer) etag = created.e_tag - indexer.description = "updated" await client.create_or_update_indexer(indexer) @@ -176,11 +140,9 @@ async def test_create_or_update_indexer_if_unchanged(self, api_key, endpoint, in with pytest.raises(HttpResponseError): await client.create_or_update_indexer(indexer, match_condition=MatchConditions.IfNotModified) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - async def test_delete_indexer_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer = await self._prepare_indexer(endpoint, api_key) + async def _test_delete_indexer_if_unchanged(self, client, index_client, storage_cs, container_name): + name = "delunch" + indexer = await self._prepare_indexer(client, index_client, storage_cs, name, container_name) result = await client.create_indexer(indexer) etag = result.e_tag diff --git a/sdk/search/azure-search-documents/tests/conftest.py b/sdk/search/azure-search-documents/tests/conftest.py new file mode 100644 index 000000000000..55fabc4d34a3 --- /dev/null +++ b/sdk/search/azure-search-documents/tests/conftest.py @@ -0,0 +1,35 @@ +# ------------------------------------------------------------------------ +# Copyright (c) Microsoft Corporation. All rights reserved. +# Licensed under the MIT License. See License.txt in the project root for +# license information. +# ------------------------------------------------------------------------- + +import sys +import pytest +from devtools_testutils import test_proxy +from devtools_testutils.sanitizers import add_remove_header_sanitizer, add_general_regex_sanitizer + +# Ignore async tests for Python < 3.5 +collect_ignore = [] +if sys.version_info < (3, 5): + collect_ignore.append("async_tests") + +@pytest.fixture(scope="session", autouse=True) +def add_sanitizers(test_proxy): + add_remove_header_sanitizer(headers="api-key") + + # Ensure all search service endpoint names are mocked to "test-service" + add_general_regex_sanitizer( + value="://fakesearchendpoint.search.windows.net", + regex=r"://(.+).search.windows.net" + ) + # Remove storage connection strings from recordings + add_general_regex_sanitizer( + value="AccountKey=FAKE;", + regex=r"AccountKey=([^;]+);" + ) + # Remove storage account names from recordings + add_general_regex_sanitizer( + value="AccountName=fakestoragecs;", + regex=r"AccountName=([^;]+);" + ) diff --git a/sdk/search/azure-search-documents/tests/consts.py b/sdk/search/azure-search-documents/tests/consts.py deleted file mode 100644 index ce6b239953fb..000000000000 --- a/sdk/search/azure-search-documents/tests/consts.py +++ /dev/null @@ -1,9 +0,0 @@ -# ------------------------------------ -# Copyright (c) Microsoft Corporation. -# Licensed under the MIT License. -# ----------------------------------- - -TEST_SERVICE_NAME = "test-service-name" -SERVICE_URL = "https://{}.search.windows.net/indexes?api-version=2021-04-30-Preview".format( - TEST_SERVICE_NAME -) diff --git a/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_client_basic_live_async.pyTestSearchClientAsynctest_get_document.json b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_client_basic_live_async.pyTestSearchClientAsynctest_get_document.json new file mode 100644 index 000000000000..7c529a51fc97 --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_client_basic_live_async.pyTestSearchClientAsynctest_get_document.json @@ -0,0 +1,597 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e44990ed-7fc3-11ec-ba49-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1000", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:53:05 GMT", + "elapsed-time": "11", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e44990ed-7fc3-11ec-ba49-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 5, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00272\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e45ce11b-7fc3-11ec-8ac1-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "469", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:53:05 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e45ce11b-7fc3-11ec-8ac1-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "2", + "hotelName": "Roach Motel", + "description": "Cheapest hotel in town. Infact, a motel.", + "descriptionFr": "H\u00C3\u00B4tel le moins cher en ville. Infact, un motel.", + "category": "Budget", + "tags": [ + "motel", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": true, + "lastRenovationDate": "1982-04-28T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 49.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00273\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e46f2602-7fc3-11ec-98b3-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "438", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:53:05 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e46f2602-7fc3-11ec-98b3-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "3", + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "descriptionFr": "H\u00C3\u00B4tel le plus populaire en ville", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 46.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00274\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e480d228-7fc3-11ec-b8bc-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "416", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:53:05 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e480d228-7fc3-11ec-b8bc-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "4", + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "descriptionFr": "Assez bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00275\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e49162b4-7fc3-11ec-a532-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "418", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:53:05 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e49162b4-7fc3-11ec-a532-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "5", + "hotelName": "Comfy Place", + "description": "Another good hotel", + "descriptionFr": "Un autre bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "2012-08-12T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00276\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e4a42561-7fc3-11ec-8d81-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "279", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:53:07 GMT", + "elapsed-time": "5", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e4a42561-7fc3-11ec-8d81-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "6", + "hotelName": null, + "description": "Surprisingly expensive. Model suites have an ocean-view.", + "descriptionFr": null, + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": null, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00277\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e4b57474-7fc3-11ec-906e-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "402", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:53:07 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e4b57474-7fc3-11ec-906e-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "7", + "hotelName": "Modern Stay", + "description": "Modern architecture, very polite staff and very clean. Also very affordable.", + "descriptionFr": "Architecture moderne, personnel poli et tr\u00C3\u00A8s propre. Aussi tr\u00C3\u00A8s abordable.", + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": null, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00278\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e4c698f6-7fc3-11ec-8926-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "483", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:53:07 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e4c698f6-7fc3-11ec-8926-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "8", + "hotelName": null, + "description": "Has some road noise and is next to the very police station. Bathrooms had morel coverings.", + "descriptionFr": "Il y a du bruit de la route et se trouve \u00C3\u00A0 c\u00C3\u00B4t\u00C3\u00A9 de la station de police. Les salles de bain avaient des rev\u00C3\u00AAtements de morilles.", + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": null, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00279\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e4d90b13-7fc3-11ec-83b7-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1742", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:53:07 GMT", + "elapsed-time": "10", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e4d90b13-7fc3-11ec-83b7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "9", + "hotelName": "Secret Point Motel", + "description": "The hotel is ideally located on the main commercial artery of the city in the heart of New York. A few minutes away is Time\u0027s Square and the historic centre of the city, as well as other places of interest that make New York one of America\u0027s most attractive and cosmopolitan cities.", + "descriptionFr": "L\u0027h\u00C3\u00B4tel est id\u00C3\u00A9alement situ\u00C3\u00A9 sur la principale art\u00C3\u00A8re commerciale de la ville en plein c\u00C5\u201Cur de New York. A quelques minutes se trouve la place du temps et le centre historique de la ville, ainsi que d\u0027autres lieux d\u0027int\u00C3\u00A9r\u00C3\u00AAt qui font de New York l\u0027une des villes les plus attractives et cosmopolites de l\u0027Am\u00C3\u00A9rique.", + "category": "Boutique", + "tags": [ + "pool", + "air conditioning", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1970-01-18T05:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -73.975403, + 40.760586 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "677 5th Ave", + "city": "New York", + "stateProvince": "NY", + "country": "USA", + "postalCode": "10022" + }, + "rooms": [ + { + "description": "Budget Room, 1 Queen Bed (Cityside)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (c\u00C3\u00B4t\u00C3\u00A9 ville)", + "type": "Budget Room", + "baseRate": 9.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd" + ] + }, + { + "description": "Budget Room, 1 King Bed (Mountain View)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 tr\u00C3\u00A8s grand lit (Mountain View)", + "type": "Budget Room", + "baseRate": 8.09, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd", + "jacuzzi tub" + ] + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u002710\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e4eb8af5-7fc3-11ec-b178-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1466", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:53:07 GMT", + "elapsed-time": "23", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e4eb8af5-7fc3-11ec-b178-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "10", + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "descriptionFr": "\u00C3\u2030conomisez jusqu\u0027\u00C3\u00A0 50% sur les h\u00C3\u00B4tels traditionnels. WiFi gratuit, tr\u00C3\u00A8s bien situ\u00C3\u00A9 pr\u00C3\u00A8s du centre-ville, cuisine compl\u00C3\u00A8te, laveuse \u0026 s\u00C3\u00A9cheuse, support 24/7, bowling, centre de fitness et plus encore.", + "category": "Budget", + "tags": [ + "24-hour front desk service", + "coffee in lobby", + "restaurant" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1999-09-06T00:00:00Z", + "rating": 3, + "location": { + "type": "Point", + "coordinates": [ + -78.940483, + 35.90416 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "6910 Fayetteville Rd", + "city": "Durham", + "stateProvince": "NC", + "country": "USA", + "postalCode": "27713" + }, + "rooms": [ + { + "description": "Suite, 1 King Bed (Amenities)", + "descriptionFr": "Suite, 1 tr\u00C3\u00A8s grand lit (Services)", + "type": "Suite", + "baseRate": 2.44, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "coffee maker" + ] + }, + { + "description": "Budget Room, 1 Queen Bed (Amenities)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (Services)", + "type": "Budget Room", + "baseRate": 7.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": false, + "tags": [ + "coffee maker" + ] + } + ] + } + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_client_basic_live_async.pyTestSearchClientAsynctest_get_document_count.json b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_client_basic_live_async.pyTestSearchClientAsynctest_get_document_count.json new file mode 100644 index 000000000000..53d84d53e3fd --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_client_basic_live_async.pyTestSearchClientAsynctest_get_document_count.json @@ -0,0 +1,33 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "dffbb23f-7fc3-11ec-9142-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:52:59 GMT", + "elapsed-time": "5", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "dffbb23f-7fc3-11ec-9142-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF10" + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_client_basic_live_async.pyTestSearchClientAsynctest_get_document_missing.json b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_client_basic_live_async.pyTestSearchClientAsynctest_get_document_missing.json new file mode 100644 index 000000000000..6b155bb53b61 --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_client_basic_live_async.pyTestSearchClientAsynctest_get_document_missing.json @@ -0,0 +1,28 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271000\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e8e50328-7fc3-11ec-a90a-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:53:13 GMT", + "elapsed-time": "5", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "e8e50328-7fc3-11ec-a90a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_client_buffered_sender_live_async.pyTestSearchIndexingBufferedSenderAsynctest_search_client_index_buffered_sender.json b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_client_buffered_sender_live_async.pyTestSearchIndexingBufferedSenderAsynctest_search_client_index_buffered_sender.json new file mode 100644 index 000000000000..12966e2f1462 --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_client_buffered_sender_live_async.pyTestSearchIndexingBufferedSenderAsynctest_search_client_index_buffered_sender.json @@ -0,0 +1,1522 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c4a756f8-7fc3-11ec-ae74-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "6696", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:52:13 GMT", + "elapsed-time": "21", + "ETag": "W/\u00220x8D9E1E7A6011F10\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c4a756f8-7fc3-11ec-ae74-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E7A6011F10\u0022", + "name": "drgqefsg", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "hotelName", + "type": "Edm.String", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "description", + "type": "Edm.String", + "searchable": true, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": "en.lucene", + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "descriptionFr", + "type": "Edm.String", + "searchable": true, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": "fr.lucene", + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "category", + "type": "Edm.String", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "tags", + "type": "Collection(Edm.String)", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": false, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "parkingIncluded", + "type": "Edm.Boolean", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "smokingAllowed", + "type": "Edm.Boolean", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "lastRenovationDate", + "type": "Edm.DateTimeOffset", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "rating", + "type": "Edm.Int32", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "location", + "type": "Edm.GeographyPoint", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "address", + "type": "Edm.ComplexType", + "fields": [ + { + "name": "streetAddress", + "type": "Edm.String", + "searchable": true, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "city", + "type": "Edm.String", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "stateProvince", + "type": "Edm.String", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "country", + "type": "Edm.String", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "postalCode", + "type": "Edm.String", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ] + }, + { + "name": "rooms", + "type": "Collection(Edm.ComplexType)", + "fields": [ + { + "name": "description", + "type": "Edm.String", + "searchable": true, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": "en.lucene", + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "descriptionFr", + "type": "Edm.String", + "searchable": true, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": "fr.lucene", + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "type", + "type": "Edm.String", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": false, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": false, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "bedOptions", + "type": "Edm.String", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": false, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "sleepsCount", + "type": "Edm.Int32", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": false, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "smokingAllowed", + "type": "Edm.Boolean", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": false, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "tags", + "type": "Collection(Edm.String)", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": false, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ] + } + ], + "scoringProfiles": [ + { + "name": "nearest", + "functionAggregation": "sum", + "text": null, + "functions": [ + { + "fieldName": "location", + "interpolation": "linear", + "type": "distance", + "boost": 2.0, + "freshness": null, + "magnitude": null, + "distance": { + "referencePointParameter": "myloc", + "boostingDistance": 100.0 + }, + "tag": null + } + ] + } + ], + "corsOptions": null, + "suggesters": [ + { + "name": "sg", + "searchMode": "analyzingInfixMatching", + "sourceFields": [ + "description", + "hotelName" + ] + } + ], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "217", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c50bf41a-7fc3-11ec-a92f-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1000", + "rating": 5, + "rooms": [], + "hotelName": "Azure Inn", + "@search.action": "upload" + }, + { + "hotelId": "1001", + "rating": 4, + "rooms": [], + "hotelName": "Redmond Hotel", + "@search.action": "upload" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "143", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:52:13 GMT", + "elapsed-time": "41", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c50bf41a-7fc3-11ec-a92f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1000", + "status": true, + "errorMessage": null, + "statusCode": 201 + }, + { + "key": "1001", + "status": true, + "errorMessage": null, + "statusCode": 201 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c6eec159-7fc3-11ec-b0fe-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:52:17 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c6eec159-7fc3-11ec-b0fe-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF12" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271000\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c7052f3d-7fc3-11ec-a867-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "232", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:52:17 GMT", + "elapsed-time": "11", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c7052f3d-7fc3-11ec-a867-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1000", + "hotelName": "Azure Inn", + "description": null, + "descriptionFr": null, + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": 5, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271001\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c718a964-7fc3-11ec-8701-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "236", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:52:17 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c718a964-7fc3-11ec-8701-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1001", + "hotelName": "Redmond Hotel", + "description": null, + "descriptionFr": null, + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": 4, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "214", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c72a89ae-7fc3-11ec-82e0-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1002", + "rating": 5, + "rooms": [], + "hotelName": "Azure Inn", + "@search.action": "upload" + }, + { + "hotelId": "3", + "rating": 4, + "rooms": [], + "hotelName": "Redmond Hotel", + "@search.action": "upload" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "140", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:52:17 GMT", + "elapsed-time": "49", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c72a89ae-7fc3-11ec-82e0-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1002", + "status": true, + "errorMessage": null, + "statusCode": 201 + }, + { + "key": "3", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c90cb344-7fc3-11ec-b0fe-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:52:20 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c90cb344-7fc3-11ec-b0fe-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF13" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "103", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c91f2b16-7fc3-11ec-892e-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "3", + "@search.action": "delete" + }, + { + "hotelId": "4", + "@search.action": "delete" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "137", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:52:20 GMT", + "elapsed-time": "27", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c91f2b16-7fc3-11ec-892e-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "3", + "status": true, + "errorMessage": null, + "statusCode": 200 + }, + { + "key": "4", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "caffd783-7fc3-11ec-8183-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:52:24 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "caffd783-7fc3-11ec-8183-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF11" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00273\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "cb1252dd-7fc3-11ec-a753-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:52:24 GMT", + "elapsed-time": "5", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "cb1252dd-7fc3-11ec-a753-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00274\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "cb259b18-7fc3-11ec-ac73-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:52:24 GMT", + "elapsed-time": "5", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "cb259b18-7fc3-11ec-ac73-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "106", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "cb38636e-7fc3-11ec-9d1d-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1003", + "@search.action": "delete" + }, + { + "hotelId": "2", + "@search.action": "delete" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "140", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:52:24 GMT", + "elapsed-time": "27", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "cb38636e-7fc3-11ec-9d1d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1003", + "status": true, + "errorMessage": null, + "statusCode": 200 + }, + { + "key": "2", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "cd17a6d3-7fc3-11ec-a804-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:52:27 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "cd17a6d3-7fc3-11ec-a804-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF10" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271003\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "cd2aeb57-7fc3-11ec-abb4-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:52:27 GMT", + "elapsed-time": "5", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "cd2aeb57-7fc3-11ec-abb4-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00272\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "cd3d1377-7fc3-11ec-9d8e-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:52:27 GMT", + "elapsed-time": "5", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "cd3d1377-7fc3-11ec-9d8e-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "127", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "cd4f8afa-7fc3-11ec-94f1-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "5", + "rating": 1, + "@search.action": "merge" + }, + { + "hotelId": "6", + "rating": 2, + "@search.action": "merge" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "137", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:52:27 GMT", + "elapsed-time": "37", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "cd4f8afa-7fc3-11ec-94f1-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "5", + "status": true, + "errorMessage": null, + "statusCode": 200 + }, + { + "key": "6", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "cf31dc10-7fc3-11ec-aad5-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:52:31 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "cf31dc10-7fc3-11ec-aad5-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF10" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00275\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "cf44e3ed-7fc3-11ec-b1de-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "418", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:52:31 GMT", + "elapsed-time": "8", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "cf44e3ed-7fc3-11ec-b1de-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "5", + "hotelName": "Comfy Place", + "description": "Another good hotel", + "descriptionFr": "Un autre bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "2012-08-12T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00276\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "cf57022b-7fc3-11ec-b5f6-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "276", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:52:31 GMT", + "elapsed-time": "5", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "cf57022b-7fc3-11ec-b5f6-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "6", + "hotelName": null, + "description": "Surprisingly expensive. Model suites have an ocean-view.", + "descriptionFr": null, + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": 2, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "130", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "cf692cc5-7fc3-11ec-b8c4-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1003", + "rating": 1, + "@search.action": "merge" + }, + { + "hotelId": "1", + "rating": 2, + "@search.action": "merge" + } + ] + }, + "StatusCode": 207, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "158", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:52:31 GMT", + "elapsed-time": "30", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "cf692cc5-7fc3-11ec-b8c4-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1003", + "status": false, + "errorMessage": "Document not found.", + "statusCode": 404 + }, + { + "key": "1", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "d148d8d1-7fc3-11ec-b242-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:52:34 GMT", + "elapsed-time": "19", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "d148d8d1-7fc3-11ec-b242-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF10" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271003\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "d15cec14-7fc3-11ec-bf8d-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:52:34 GMT", + "elapsed-time": "5", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "d15cec14-7fc3-11ec-bf8d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "d16ed427-7fc3-11ec-889d-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1000", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:52:34 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "d16ed427-7fc3-11ec-889d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 2, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "146", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "d17fec70-7fc3-11ec-9642-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1003", + "rating": 1, + "@search.action": "mergeOrUpload" + }, + { + "hotelId": "1", + "rating": 2, + "@search.action": "mergeOrUpload" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "140", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:52:34 GMT", + "elapsed-time": "23", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "d17fec70-7fc3-11ec-9642-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1003", + "status": true, + "errorMessage": null, + "statusCode": 201 + }, + { + "key": "1", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "d35dfb37-7fc3-11ec-8264-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:52:37 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "d35dfb37-7fc3-11ec-8264-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF11" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271003\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "d3710921-7fc3-11ec-a4d7-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "225", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:52:37 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "d3710921-7fc3-11ec-a4d7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1003", + "hotelName": null, + "description": null, + "descriptionFr": null, + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": 1, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "d3825993-7fc3-11ec-9357-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1000", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:52:37 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "d3825993-7fc3-11ec-9357-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 2, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_client_index_document_live_async.pyTestSearchClientDocumentsAsynctest_search_client_index_document.json b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_client_index_document_live_async.pyTestSearchClientDocumentsAsynctest_search_client_index_document.json new file mode 100644 index 000000000000..5b19ab2f3542 --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_client_index_document_live_async.pyTestSearchClientDocumentsAsynctest_search_client_index_document.json @@ -0,0 +1,1041 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "217", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "adf43517-7fc3-11ec-83db-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1000", + "rating": 5, + "rooms": [], + "hotelName": "Azure Inn", + "@search.action": "upload" + }, + { + "hotelId": "1001", + "rating": 4, + "rooms": [], + "hotelName": "Redmond Hotel", + "@search.action": "upload" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "143", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:34 GMT", + "elapsed-time": "31", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "adf43517-7fc3-11ec-83db-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1000", + "status": true, + "errorMessage": null, + "statusCode": 201 + }, + { + "key": "1001", + "status": true, + "errorMessage": null, + "statusCode": 201 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b0245f20-7fc3-11ec-8c6c-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:51:38 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "b0245f20-7fc3-11ec-8c6c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF12" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271000\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b039e305-7fc3-11ec-a050-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "232", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:38 GMT", + "elapsed-time": "14", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "b039e305-7fc3-11ec-a050-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1000", + "hotelName": "Azure Inn", + "description": null, + "descriptionFr": null, + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": 5, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271001\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b04e536c-7fc3-11ec-8919-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "236", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:38 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "b04e536c-7fc3-11ec-8919-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1001", + "hotelName": "Redmond Hotel", + "description": null, + "descriptionFr": null, + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": 4, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "214", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b060e8c6-7fc3-11ec-8f52-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1002", + "rating": 5, + "rooms": [], + "hotelName": "Azure Inn", + "@search.action": "upload" + }, + { + "hotelId": "3", + "rating": 4, + "rooms": [], + "hotelName": "Redmond Hotel", + "@search.action": "upload" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "140", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:38 GMT", + "elapsed-time": "38", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "b060e8c6-7fc3-11ec-8f52-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1002", + "status": true, + "errorMessage": null, + "statusCode": 201 + }, + { + "key": "3", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "103", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b077a2fa-7fc3-11ec-9adb-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "3", + "@search.action": "delete" + }, + { + "hotelId": "4", + "@search.action": "delete" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "137", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:38 GMT", + "elapsed-time": "30", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "b077a2fa-7fc3-11ec-9adb-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "3", + "status": true, + "errorMessage": null, + "statusCode": 200 + }, + { + "key": "4", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b2587725-7fc3-11ec-9b6a-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:51:42 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "b2587725-7fc3-11ec-9b6a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF11" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00273\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b26d5855-7fc3-11ec-86af-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:51:42 GMT", + "elapsed-time": "5", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "b26d5855-7fc3-11ec-86af-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00274\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b2820119-7fc3-11ec-b9e7-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:51:42 GMT", + "elapsed-time": "5", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "b2820119-7fc3-11ec-b9e7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "106", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b2960bf5-7fc3-11ec-9afa-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1003", + "@search.action": "delete" + }, + { + "hotelId": "2", + "@search.action": "delete" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "140", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:42 GMT", + "elapsed-time": "32", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "b2960bf5-7fc3-11ec-9afa-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1003", + "status": true, + "errorMessage": null, + "statusCode": 200 + }, + { + "key": "2", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b4785d3b-7fc3-11ec-9c2a-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:51:46 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "b4785d3b-7fc3-11ec-9c2a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF10" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271003\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b48bf1ee-7fc3-11ec-aad2-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:51:46 GMT", + "elapsed-time": "4", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "b48bf1ee-7fc3-11ec-aad2-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00272\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b49e8817-7fc3-11ec-ba2f-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:51:46 GMT", + "elapsed-time": "5", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "b49e8817-7fc3-11ec-ba2f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "127", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b4b178e4-7fc3-11ec-a867-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "5", + "rating": 1, + "@search.action": "merge" + }, + { + "hotelId": "6", + "rating": 2, + "@search.action": "merge" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "137", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:46 GMT", + "elapsed-time": "34", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "b4b178e4-7fc3-11ec-a867-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "5", + "status": true, + "errorMessage": null, + "statusCode": 200 + }, + { + "key": "6", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b692e602-7fc3-11ec-8142-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:51:49 GMT", + "elapsed-time": "11", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "b692e602-7fc3-11ec-8142-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF10" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00275\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b6a6ab1d-7fc3-11ec-b839-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "418", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:49 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "b6a6ab1d-7fc3-11ec-b839-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "5", + "hotelName": "Comfy Place", + "description": "Another good hotel", + "descriptionFr": "Un autre bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "2012-08-12T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00276\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b6bb2f5c-7fc3-11ec-973e-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "276", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:49 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "b6bb2f5c-7fc3-11ec-973e-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "6", + "hotelName": null, + "description": "Surprisingly expensive. Model suites have an ocean-view.", + "descriptionFr": null, + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": 2, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "130", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b6ce2e03-7fc3-11ec-b37a-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1003", + "rating": 1, + "@search.action": "merge" + }, + { + "hotelId": "1", + "rating": 2, + "@search.action": "merge" + } + ] + }, + "StatusCode": 207, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "158", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:49 GMT", + "elapsed-time": "30", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "b6ce2e03-7fc3-11ec-b37a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1003", + "status": false, + "errorMessage": "Document not found.", + "statusCode": 404 + }, + { + "key": "1", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b8b0d10b-7fc3-11ec-892e-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:51:52 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "b8b0d10b-7fc3-11ec-892e-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF10" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271003\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b8c485b0-7fc3-11ec-9658-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:51:52 GMT", + "elapsed-time": "5", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "b8c485b0-7fc3-11ec-9658-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b8d7f1f8-7fc3-11ec-9ae7-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1000", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:52 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "b8d7f1f8-7fc3-11ec-9ae7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 2, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "146", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "b8eba8c0-7fc3-11ec-8bc1-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1003", + "rating": 1, + "@search.action": "mergeOrUpload" + }, + { + "hotelId": "1", + "rating": 2, + "@search.action": "mergeOrUpload" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "140", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:52 GMT", + "elapsed-time": "25", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "b8eba8c0-7fc3-11ec-8bc1-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1003", + "status": true, + "errorMessage": null, + "statusCode": 201 + }, + { + "key": "1", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "bacb05df-7fc3-11ec-a950-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:51:55 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "bacb05df-7fc3-11ec-a950-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF11" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271003\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "badf54a1-7fc3-11ec-a816-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "225", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:56 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "badf54a1-7fc3-11ec-a816-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1003", + "hotelName": null, + "description": null, + "descriptionFr": null, + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": 1, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "baf199d1-7fc3-11ec-bfef-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1000", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:56 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "baf199d1-7fc3-11ec-bfef-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 2, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_client_search_live_async.pyTestClientTestAsynctest_search_client.json b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_client_search_live_async.pyTestClientTestAsynctest_search_client.json new file mode 100644 index 000000000000..695318c6b456 --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_client_search_live_async.pyTestClientTestAsynctest_search_client.json @@ -0,0 +1,2383 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "19", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a4214271-7fc3-11ec-9e22-74c63bed1137" + }, + "RequestBody": { + "search": "hotel" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "6156", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:18 GMT", + "elapsed-time": "45", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a4214271-7fc3-11ec-9e22-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.score": 0.7960079, + "hotelId": "10", + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "descriptionFr": "\u00C3\u2030conomisez jusqu\u0027\u00C3\u00A0 50% sur les h\u00C3\u00B4tels traditionnels. WiFi gratuit, tr\u00C3\u00A8s bien situ\u00C3\u00A9 pr\u00C3\u00A8s du centre-ville, cuisine compl\u00C3\u00A8te, laveuse \u0026 s\u00C3\u00A9cheuse, support 24/7, bowling, centre de fitness et plus encore.", + "category": "Budget", + "tags": [ + "24-hour front desk service", + "coffee in lobby", + "restaurant" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1999-09-06T00:00:00Z", + "rating": 3, + "location": { + "type": "Point", + "coordinates": [ + -78.940483, + 35.90416 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "6910 Fayetteville Rd", + "city": "Durham", + "stateProvince": "NC", + "country": "USA", + "postalCode": "27713" + }, + "rooms": [ + { + "description": "Suite, 1 King Bed (Amenities)", + "descriptionFr": "Suite, 1 tr\u00C3\u00A8s grand lit (Services)", + "type": "Suite", + "baseRate": 2.44, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "coffee maker" + ] + }, + { + "description": "Budget Room, 1 Queen Bed (Amenities)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (Services)", + "type": "Budget Room", + "baseRate": 7.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": false, + "tags": [ + "coffee maker" + ] + } + ] + }, + { + "@search.score": 0.27958742, + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 5, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.26639014, + "hotelId": "3", + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "descriptionFr": "H\u00C3\u00B4tel le plus populaire en ville", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 46.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "4", + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "descriptionFr": "Assez bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "5", + "hotelName": "Comfy Place", + "description": "Another good hotel", + "descriptionFr": "Un autre bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "2012-08-12T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.11774718, + "hotelId": "9", + "hotelName": "Secret Point Motel", + "description": "The hotel is ideally located on the main commercial artery of the city in the heart of New York. A few minutes away is Time\u0027s Square and the historic centre of the city, as well as other places of interest that make New York one of America\u0027s most attractive and cosmopolitan cities.", + "descriptionFr": "L\u0027h\u00C3\u00B4tel est id\u00C3\u00A9alement situ\u00C3\u00A9 sur la principale art\u00C3\u00A8re commerciale de la ville en plein c\u00C5\u201Cur de New York. A quelques minutes se trouve la place du temps et le centre historique de la ville, ainsi que d\u0027autres lieux d\u0027int\u00C3\u00A9r\u00C3\u00AAt qui font de New York l\u0027une des villes les plus attractives et cosmopolites de l\u0027Am\u00C3\u00A9rique.", + "category": "Boutique", + "tags": [ + "pool", + "air conditioning", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1970-01-18T05:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -73.975403, + 40.760586 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "677 5th Ave", + "city": "New York", + "stateProvince": "NY", + "country": "USA", + "postalCode": "10022" + }, + "rooms": [ + { + "description": "Budget Room, 1 Queen Bed (Cityside)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (c\u00C3\u00B4t\u00C3\u00A9 ville)", + "type": "Budget Room", + "baseRate": 9.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd" + ] + }, + { + "description": "Budget Room, 1 King Bed (Mountain View)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 tr\u00C3\u00A8s grand lit (Mountain View)", + "type": "Budget Room", + "baseRate": 8.09, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd", + "jacuzzi tub" + ] + } + ] + }, + { + "@search.score": 0.113759264, + "hotelId": "2", + "hotelName": "Roach Motel", + "description": "Cheapest hotel in town. Infact, a motel.", + "descriptionFr": "H\u00C3\u00B4tel le moins cher en ville. Infact, un motel.", + "category": "Budget", + "tags": [ + "motel", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": true, + "lastRenovationDate": "1982-04-28T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 49.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "19", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a4911c47-7fc3-11ec-9e2c-74c63bed1137" + }, + "RequestBody": { + "search": "motel" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "2277", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:19 GMT", + "elapsed-time": "11", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a4911c47-7fc3-11ec-9e2c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.score": 3.4320152, + "hotelId": "2", + "hotelName": "Roach Motel", + "description": "Cheapest hotel in town. Infact, a motel.", + "descriptionFr": "H\u00C3\u00B4tel le moins cher en ville. Infact, un motel.", + "category": "Budget", + "tags": [ + "motel", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": true, + "lastRenovationDate": "1982-04-28T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 49.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.49191087, + "hotelId": "9", + "hotelName": "Secret Point Motel", + "description": "The hotel is ideally located on the main commercial artery of the city in the heart of New York. A few minutes away is Time\u0027s Square and the historic centre of the city, as well as other places of interest that make New York one of America\u0027s most attractive and cosmopolitan cities.", + "descriptionFr": "L\u0027h\u00C3\u00B4tel est id\u00C3\u00A9alement situ\u00C3\u00A9 sur la principale art\u00C3\u00A8re commerciale de la ville en plein c\u00C5\u201Cur de New York. A quelques minutes se trouve la place du temps et le centre historique de la ville, ainsi que d\u0027autres lieux d\u0027int\u00C3\u00A9r\u00C3\u00AAt qui font de New York l\u0027une des villes les plus attractives et cosmopolites de l\u0027Am\u00C3\u00A9rique.", + "category": "Boutique", + "tags": [ + "pool", + "air conditioning", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1970-01-18T05:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -73.975403, + 40.760586 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "677 5th Ave", + "city": "New York", + "stateProvince": "NY", + "country": "USA", + "postalCode": "10022" + }, + "rooms": [ + { + "description": "Budget Room, 1 Queen Bed (Cityside)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (c\u00C3\u00B4t\u00C3\u00A9 ville)", + "type": "Budget Room", + "baseRate": 9.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd" + ] + }, + { + "description": "Budget Room, 1 King Bed (Mountain View)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 tr\u00C3\u00A8s grand lit (Mountain View)", + "type": "Budget Room", + "baseRate": 8.09, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd", + "jacuzzi tub" + ] + } + ] + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "29", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a4a816ca-7fc3-11ec-b22b-74c63bed1137" + }, + "RequestBody": { + "search": "hotel", + "top": 3 + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "2998", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:19 GMT", + "elapsed-time": "13", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a4a816ca-7fc3-11ec-b22b-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.score": 0.7960079, + "hotelId": "10", + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "descriptionFr": "\u00C3\u2030conomisez jusqu\u0027\u00C3\u00A0 50% sur les h\u00C3\u00B4tels traditionnels. WiFi gratuit, tr\u00C3\u00A8s bien situ\u00C3\u00A9 pr\u00C3\u00A8s du centre-ville, cuisine compl\u00C3\u00A8te, laveuse \u0026 s\u00C3\u00A9cheuse, support 24/7, bowling, centre de fitness et plus encore.", + "category": "Budget", + "tags": [ + "24-hour front desk service", + "coffee in lobby", + "restaurant" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1999-09-06T00:00:00Z", + "rating": 3, + "location": { + "type": "Point", + "coordinates": [ + -78.940483, + 35.90416 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "6910 Fayetteville Rd", + "city": "Durham", + "stateProvince": "NC", + "country": "USA", + "postalCode": "27713" + }, + "rooms": [ + { + "description": "Suite, 1 King Bed (Amenities)", + "descriptionFr": "Suite, 1 tr\u00C3\u00A8s grand lit (Services)", + "type": "Suite", + "baseRate": 2.44, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "coffee maker" + ] + }, + { + "description": "Budget Room, 1 Queen Bed (Amenities)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (Services)", + "type": "Budget Room", + "baseRate": 7.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": false, + "tags": [ + "coffee maker" + ] + } + ] + }, + { + "@search.score": 0.27958742, + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 5, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.26639014, + "hotelId": "3", + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "descriptionFr": "H\u00C3\u00B4tel le plus populaire en ville", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 46.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "29", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a4bcef02-7fc3-11ec-aff1-74c63bed1137" + }, + "RequestBody": { + "search": "motel", + "top": 3 + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "2277", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:19 GMT", + "elapsed-time": "14", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a4bcef02-7fc3-11ec-aff1-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.score": 3.4320152, + "hotelId": "2", + "hotelName": "Roach Motel", + "description": "Cheapest hotel in town. Infact, a motel.", + "descriptionFr": "H\u00C3\u00B4tel le moins cher en ville. Infact, un motel.", + "category": "Budget", + "tags": [ + "motel", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": true, + "lastRenovationDate": "1982-04-28T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 49.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.49191087, + "hotelId": "9", + "hotelName": "Secret Point Motel", + "description": "The hotel is ideally located on the main commercial artery of the city in the heart of New York. A few minutes away is Time\u0027s Square and the historic centre of the city, as well as other places of interest that make New York one of America\u0027s most attractive and cosmopolitan cities.", + "descriptionFr": "L\u0027h\u00C3\u00B4tel est id\u00C3\u00A9alement situ\u00C3\u00A9 sur la principale art\u00C3\u00A8re commerciale de la ville en plein c\u00C5\u201Cur de New York. A quelques minutes se trouve la place du temps et le centre historique de la ville, ainsi que d\u0027autres lieux d\u0027int\u00C3\u00A9r\u00C3\u00AAt qui font de New York l\u0027une des villes les plus attractives et cosmopolites de l\u0027Am\u00C3\u00A9rique.", + "category": "Boutique", + "tags": [ + "pool", + "air conditioning", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1970-01-18T05:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -73.975403, + 40.760586 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "677 5th Ave", + "city": "New York", + "stateProvince": "NY", + "country": "USA", + "postalCode": "10022" + }, + "rooms": [ + { + "description": "Budget Room, 1 Queen Bed (Cityside)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (c\u00C3\u00B4t\u00C3\u00A9 ville)", + "type": "Budget Room", + "baseRate": 9.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd" + ] + }, + { + "description": "Budget Room, 1 King Bed (Mountain View)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 tr\u00C3\u00A8s grand lit (Mountain View)", + "type": "Budget Room", + "baseRate": 8.09, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd", + "jacuzzi tub" + ] + } + ] + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "125", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a4d0b694-7fc3-11ec-bb18-74c63bed1137" + }, + "RequestBody": { + "filter": "category eq \u0027Budget\u0027", + "orderby": "hotelName desc", + "search": "WiFi", + "select": "hotelName,category,description" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "608", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:19 GMT", + "elapsed-time": "12", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a4d0b694-7fc3-11ec-bb18-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.score": 0.42169982, + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "category": "Budget" + }, + { + "@search.score": 0.7373906, + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "category": "Budget" + }, + { + "@search.score": 1.3700507, + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "category": "Budget" + }, + { + "@search.score": 0.42169982, + "hotelName": "Comfy Place", + "description": "Another good hotel", + "category": "Budget" + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "125", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a4e4b25c-7fc3-11ec-b027-74c63bed1137" + }, + "RequestBody": { + "filter": "category eq \u0027Budget\u0027", + "orderby": "hotelName desc", + "search": "WiFi", + "select": "hotelName,category,description" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "608", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:19 GMT", + "elapsed-time": "13", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a4e4b25c-7fc3-11ec-b027-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.score": 0.42169982, + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "category": "Budget" + }, + { + "@search.score": 0.7373906, + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "category": "Budget" + }, + { + "@search.score": 1.3700507, + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "category": "Budget" + }, + { + "@search.score": 0.42169982, + "hotelName": "Comfy Place", + "description": "Another good hotel", + "category": "Budget" + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "19", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a4f95fde-7fc3-11ec-885a-74c63bed1137" + }, + "RequestBody": { + "search": "hotel" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "6156", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:19 GMT", + "elapsed-time": "15", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a4f95fde-7fc3-11ec-885a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.score": 0.7960079, + "hotelId": "10", + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "descriptionFr": "\u00C3\u2030conomisez jusqu\u0027\u00C3\u00A0 50% sur les h\u00C3\u00B4tels traditionnels. WiFi gratuit, tr\u00C3\u00A8s bien situ\u00C3\u00A9 pr\u00C3\u00A8s du centre-ville, cuisine compl\u00C3\u00A8te, laveuse \u0026 s\u00C3\u00A9cheuse, support 24/7, bowling, centre de fitness et plus encore.", + "category": "Budget", + "tags": [ + "24-hour front desk service", + "coffee in lobby", + "restaurant" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1999-09-06T00:00:00Z", + "rating": 3, + "location": { + "type": "Point", + "coordinates": [ + -78.940483, + 35.90416 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "6910 Fayetteville Rd", + "city": "Durham", + "stateProvince": "NC", + "country": "USA", + "postalCode": "27713" + }, + "rooms": [ + { + "description": "Suite, 1 King Bed (Amenities)", + "descriptionFr": "Suite, 1 tr\u00C3\u00A8s grand lit (Services)", + "type": "Suite", + "baseRate": 2.44, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "coffee maker" + ] + }, + { + "description": "Budget Room, 1 Queen Bed (Amenities)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (Services)", + "type": "Budget Room", + "baseRate": 7.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": false, + "tags": [ + "coffee maker" + ] + } + ] + }, + { + "@search.score": 0.27958742, + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 5, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.26639014, + "hotelId": "3", + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "descriptionFr": "H\u00C3\u00B4tel le plus populaire en ville", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 46.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "4", + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "descriptionFr": "Assez bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "5", + "hotelName": "Comfy Place", + "description": "Another good hotel", + "descriptionFr": "Un autre bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "2012-08-12T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.11774718, + "hotelId": "9", + "hotelName": "Secret Point Motel", + "description": "The hotel is ideally located on the main commercial artery of the city in the heart of New York. A few minutes away is Time\u0027s Square and the historic centre of the city, as well as other places of interest that make New York one of America\u0027s most attractive and cosmopolitan cities.", + "descriptionFr": "L\u0027h\u00C3\u00B4tel est id\u00C3\u00A9alement situ\u00C3\u00A9 sur la principale art\u00C3\u00A8re commerciale de la ville en plein c\u00C5\u201Cur de New York. A quelques minutes se trouve la place du temps et le centre historique de la ville, ainsi que d\u0027autres lieux d\u0027int\u00C3\u00A9r\u00C3\u00AAt qui font de New York l\u0027une des villes les plus attractives et cosmopolites de l\u0027Am\u00C3\u00A9rique.", + "category": "Boutique", + "tags": [ + "pool", + "air conditioning", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1970-01-18T05:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -73.975403, + 40.760586 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "677 5th Ave", + "city": "New York", + "stateProvince": "NY", + "country": "USA", + "postalCode": "10022" + }, + "rooms": [ + { + "description": "Budget Room, 1 Queen Bed (Cityside)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (c\u00C3\u00B4t\u00C3\u00A9 ville)", + "type": "Budget Room", + "baseRate": 9.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd" + ] + }, + { + "description": "Budget Room, 1 King Bed (Mountain View)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 tr\u00C3\u00A8s grand lit (Mountain View)", + "type": "Budget Room", + "baseRate": 8.09, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd", + "jacuzzi tub" + ] + } + ] + }, + { + "@search.score": 0.113759264, + "hotelId": "2", + "hotelName": "Roach Motel", + "description": "Cheapest hotel in town. Infact, a motel.", + "descriptionFr": "H\u00C3\u00B4tel le moins cher en ville. Infact, un motel.", + "category": "Budget", + "tags": [ + "motel", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": true, + "lastRenovationDate": "1982-04-28T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 49.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "34", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a50e1138-7fc3-11ec-a7c7-74c63bed1137" + }, + "RequestBody": { + "count": true, + "search": "hotel" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "6173", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:19 GMT", + "elapsed-time": "12", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a50e1138-7fc3-11ec-a7c7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.count": 7, + "value": [ + { + "@search.score": 0.7960079, + "hotelId": "10", + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "descriptionFr": "\u00C3\u2030conomisez jusqu\u0027\u00C3\u00A0 50% sur les h\u00C3\u00B4tels traditionnels. WiFi gratuit, tr\u00C3\u00A8s bien situ\u00C3\u00A9 pr\u00C3\u00A8s du centre-ville, cuisine compl\u00C3\u00A8te, laveuse \u0026 s\u00C3\u00A9cheuse, support 24/7, bowling, centre de fitness et plus encore.", + "category": "Budget", + "tags": [ + "24-hour front desk service", + "coffee in lobby", + "restaurant" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1999-09-06T00:00:00Z", + "rating": 3, + "location": { + "type": "Point", + "coordinates": [ + -78.940483, + 35.90416 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "6910 Fayetteville Rd", + "city": "Durham", + "stateProvince": "NC", + "country": "USA", + "postalCode": "27713" + }, + "rooms": [ + { + "description": "Suite, 1 King Bed (Amenities)", + "descriptionFr": "Suite, 1 tr\u00C3\u00A8s grand lit (Services)", + "type": "Suite", + "baseRate": 2.44, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "coffee maker" + ] + }, + { + "description": "Budget Room, 1 Queen Bed (Amenities)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (Services)", + "type": "Budget Room", + "baseRate": 7.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": false, + "tags": [ + "coffee maker" + ] + } + ] + }, + { + "@search.score": 0.27958742, + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 5, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.26639014, + "hotelId": "3", + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "descriptionFr": "H\u00C3\u00B4tel le plus populaire en ville", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 46.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "4", + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "descriptionFr": "Assez bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "5", + "hotelName": "Comfy Place", + "description": "Another good hotel", + "descriptionFr": "Un autre bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "2012-08-12T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.11774718, + "hotelId": "9", + "hotelName": "Secret Point Motel", + "description": "The hotel is ideally located on the main commercial artery of the city in the heart of New York. A few minutes away is Time\u0027s Square and the historic centre of the city, as well as other places of interest that make New York one of America\u0027s most attractive and cosmopolitan cities.", + "descriptionFr": "L\u0027h\u00C3\u00B4tel est id\u00C3\u00A9alement situ\u00C3\u00A9 sur la principale art\u00C3\u00A8re commerciale de la ville en plein c\u00C5\u201Cur de New York. A quelques minutes se trouve la place du temps et le centre historique de la ville, ainsi que d\u0027autres lieux d\u0027int\u00C3\u00A9r\u00C3\u00AAt qui font de New York l\u0027une des villes les plus attractives et cosmopolites de l\u0027Am\u00C3\u00A9rique.", + "category": "Boutique", + "tags": [ + "pool", + "air conditioning", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1970-01-18T05:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -73.975403, + 40.760586 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "677 5th Ave", + "city": "New York", + "stateProvince": "NY", + "country": "USA", + "postalCode": "10022" + }, + "rooms": [ + { + "description": "Budget Room, 1 Queen Bed (Cityside)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (c\u00C3\u00B4t\u00C3\u00A9 ville)", + "type": "Budget Room", + "baseRate": 9.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd" + ] + }, + { + "description": "Budget Room, 1 King Bed (Mountain View)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 tr\u00C3\u00A8s grand lit (Mountain View)", + "type": "Budget Room", + "baseRate": 8.09, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd", + "jacuzzi tub" + ] + } + ] + }, + { + "@search.score": 0.113759264, + "hotelId": "2", + "hotelName": "Roach Motel", + "description": "Cheapest hotel in town. Infact, a motel.", + "descriptionFr": "H\u00C3\u00B4tel le moins cher en ville. Infact, un motel.", + "category": "Budget", + "tags": [ + "motel", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": true, + "lastRenovationDate": "1982-04-28T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 49.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "19", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a5215405-7fc3-11ec-924c-74c63bed1137" + }, + "RequestBody": { + "search": "hotel" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "6156", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:19 GMT", + "elapsed-time": "12", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a5215405-7fc3-11ec-924c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.score": 0.7960079, + "hotelId": "10", + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "descriptionFr": "\u00C3\u2030conomisez jusqu\u0027\u00C3\u00A0 50% sur les h\u00C3\u00B4tels traditionnels. WiFi gratuit, tr\u00C3\u00A8s bien situ\u00C3\u00A9 pr\u00C3\u00A8s du centre-ville, cuisine compl\u00C3\u00A8te, laveuse \u0026 s\u00C3\u00A9cheuse, support 24/7, bowling, centre de fitness et plus encore.", + "category": "Budget", + "tags": [ + "24-hour front desk service", + "coffee in lobby", + "restaurant" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1999-09-06T00:00:00Z", + "rating": 3, + "location": { + "type": "Point", + "coordinates": [ + -78.940483, + 35.90416 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "6910 Fayetteville Rd", + "city": "Durham", + "stateProvince": "NC", + "country": "USA", + "postalCode": "27713" + }, + "rooms": [ + { + "description": "Suite, 1 King Bed (Amenities)", + "descriptionFr": "Suite, 1 tr\u00C3\u00A8s grand lit (Services)", + "type": "Suite", + "baseRate": 2.44, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "coffee maker" + ] + }, + { + "description": "Budget Room, 1 Queen Bed (Amenities)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (Services)", + "type": "Budget Room", + "baseRate": 7.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": false, + "tags": [ + "coffee maker" + ] + } + ] + }, + { + "@search.score": 0.27958742, + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 5, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.26639014, + "hotelId": "3", + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "descriptionFr": "H\u00C3\u00B4tel le plus populaire en ville", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 46.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "4", + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "descriptionFr": "Assez bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "5", + "hotelName": "Comfy Place", + "description": "Another good hotel", + "descriptionFr": "Un autre bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "2012-08-12T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.11774718, + "hotelId": "9", + "hotelName": "Secret Point Motel", + "description": "The hotel is ideally located on the main commercial artery of the city in the heart of New York. A few minutes away is Time\u0027s Square and the historic centre of the city, as well as other places of interest that make New York one of America\u0027s most attractive and cosmopolitan cities.", + "descriptionFr": "L\u0027h\u00C3\u00B4tel est id\u00C3\u00A9alement situ\u00C3\u00A9 sur la principale art\u00C3\u00A8re commerciale de la ville en plein c\u00C5\u201Cur de New York. A quelques minutes se trouve la place du temps et le centre historique de la ville, ainsi que d\u0027autres lieux d\u0027int\u00C3\u00A9r\u00C3\u00AAt qui font de New York l\u0027une des villes les plus attractives et cosmopolites de l\u0027Am\u00C3\u00A9rique.", + "category": "Boutique", + "tags": [ + "pool", + "air conditioning", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1970-01-18T05:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -73.975403, + 40.760586 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "677 5th Ave", + "city": "New York", + "stateProvince": "NY", + "country": "USA", + "postalCode": "10022" + }, + "rooms": [ + { + "description": "Budget Room, 1 Queen Bed (Cityside)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (c\u00C3\u00B4t\u00C3\u00A9 ville)", + "type": "Budget Room", + "baseRate": 9.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd" + ] + }, + { + "description": "Budget Room, 1 King Bed (Mountain View)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 tr\u00C3\u00A8s grand lit (Mountain View)", + "type": "Budget Room", + "baseRate": 8.09, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd", + "jacuzzi tub" + ] + } + ] + }, + { + "@search.score": 0.113759264, + "hotelId": "2", + "hotelName": "Roach Motel", + "description": "Cheapest hotel in town. Infact, a motel.", + "descriptionFr": "H\u00C3\u00B4tel le moins cher en ville. Infact, un motel.", + "category": "Budget", + "tags": [ + "motel", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": true, + "lastRenovationDate": "1982-04-28T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 49.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "44", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a5358541-7fc3-11ec-b9dc-74c63bed1137" + }, + "RequestBody": { + "minimumCoverage": 50.0, + "search": "hotel" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "6181", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:20 GMT", + "elapsed-time": "16", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a5358541-7fc3-11ec-b9dc-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@search.coverage": 100.0, + "value": [ + { + "@search.score": 0.7960079, + "hotelId": "10", + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "descriptionFr": "\u00C3\u2030conomisez jusqu\u0027\u00C3\u00A0 50% sur les h\u00C3\u00B4tels traditionnels. WiFi gratuit, tr\u00C3\u00A8s bien situ\u00C3\u00A9 pr\u00C3\u00A8s du centre-ville, cuisine compl\u00C3\u00A8te, laveuse \u0026 s\u00C3\u00A9cheuse, support 24/7, bowling, centre de fitness et plus encore.", + "category": "Budget", + "tags": [ + "24-hour front desk service", + "coffee in lobby", + "restaurant" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1999-09-06T00:00:00Z", + "rating": 3, + "location": { + "type": "Point", + "coordinates": [ + -78.940483, + 35.90416 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "6910 Fayetteville Rd", + "city": "Durham", + "stateProvince": "NC", + "country": "USA", + "postalCode": "27713" + }, + "rooms": [ + { + "description": "Suite, 1 King Bed (Amenities)", + "descriptionFr": "Suite, 1 tr\u00C3\u00A8s grand lit (Services)", + "type": "Suite", + "baseRate": 2.44, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "coffee maker" + ] + }, + { + "description": "Budget Room, 1 Queen Bed (Amenities)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (Services)", + "type": "Budget Room", + "baseRate": 7.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": false, + "tags": [ + "coffee maker" + ] + } + ] + }, + { + "@search.score": 0.27958742, + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 5, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.26639014, + "hotelId": "3", + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "descriptionFr": "H\u00C3\u00B4tel le plus populaire en ville", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 46.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "4", + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "descriptionFr": "Assez bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "5", + "hotelName": "Comfy Place", + "description": "Another good hotel", + "descriptionFr": "Un autre bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "2012-08-12T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.11774718, + "hotelId": "9", + "hotelName": "Secret Point Motel", + "description": "The hotel is ideally located on the main commercial artery of the city in the heart of New York. A few minutes away is Time\u0027s Square and the historic centre of the city, as well as other places of interest that make New York one of America\u0027s most attractive and cosmopolitan cities.", + "descriptionFr": "L\u0027h\u00C3\u00B4tel est id\u00C3\u00A9alement situ\u00C3\u00A9 sur la principale art\u00C3\u00A8re commerciale de la ville en plein c\u00C5\u201Cur de New York. A quelques minutes se trouve la place du temps et le centre historique de la ville, ainsi que d\u0027autres lieux d\u0027int\u00C3\u00A9r\u00C3\u00AAt qui font de New York l\u0027une des villes les plus attractives et cosmopolites de l\u0027Am\u00C3\u00A9rique.", + "category": "Boutique", + "tags": [ + "pool", + "air conditioning", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1970-01-18T05:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -73.975403, + 40.760586 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "677 5th Ave", + "city": "New York", + "stateProvince": "NY", + "country": "USA", + "postalCode": "10022" + }, + "rooms": [ + { + "description": "Budget Room, 1 Queen Bed (Cityside)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (c\u00C3\u00B4t\u00C3\u00A9 ville)", + "type": "Budget Room", + "baseRate": 9.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd" + ] + }, + { + "description": "Budget Room, 1 King Bed (Mountain View)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 tr\u00C3\u00A8s grand lit (Mountain View)", + "type": "Budget Room", + "baseRate": 8.09, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd", + "jacuzzi tub" + ] + } + ] + }, + { + "@search.score": 0.113759264, + "hotelId": "2", + "hotelName": "Roach Motel", + "description": "Cheapest hotel in town. Infact, a motel.", + "descriptionFr": "H\u00C3\u00B4tel le moins cher en ville. Infact, un motel.", + "category": "Budget", + "tags": [ + "motel", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": true, + "lastRenovationDate": "1982-04-28T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 49.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "62", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a54ad321-7fc3-11ec-ba7a-74c63bed1137" + }, + "RequestBody": { + "search": "WiFi", + "select": "hotelName,category,description" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "932", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:20 GMT", + "elapsed-time": "16", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a54ad321-7fc3-11ec-ba7a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.score": 1.3700507, + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "category": "Budget" + }, + { + "@search.score": 0.82257307, + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "category": "Luxury" + }, + { + "@search.score": 0.7373906, + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "category": "Budget" + }, + { + "@search.score": 0.42169982, + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "category": "Budget" + }, + { + "@search.score": 0.42169982, + "hotelName": "Comfy Place", + "description": "Another good hotel", + "category": "Budget" + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "86", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a55e129d-7fc3-11ec-8916-74c63bed1137" + }, + "RequestBody": { + "facets": [ + "category" + ], + "search": "WiFi", + "select": "hotelName,category,description" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1022", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:20 GMT", + "elapsed-time": "18", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a55e129d-7fc3-11ec-8916-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@search.facets": { + "category": [ + { + "count": 4, + "value": "Budget" + }, + { + "count": 1, + "value": "Luxury" + } + ] + }, + "value": [ + { + "@search.score": 1.3700507, + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "category": "Budget" + }, + { + "@search.score": 0.82257307, + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "category": "Luxury" + }, + { + "@search.score": 0.7373906, + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "category": "Budget" + }, + { + "@search.score": 0.42169982, + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "category": "Budget" + }, + { + "@search.score": 0.42169982, + "hotelName": "Comfy Place", + "description": "Another good hotel", + "category": "Budget" + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.autocomplete?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "40", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a572137e-7fc3-11ec-87f2-74c63bed1137" + }, + "RequestBody": { + "search": "mot", + "suggesterName": "sg" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "52", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:20 GMT", + "elapsed-time": "8", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a572137e-7fc3-11ec-87f2-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "text": "motel", + "queryPlusText": "motel" + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.suggest?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "40", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a58ce1e7-7fc3-11ec-9abe-74c63bed1137" + }, + "RequestBody": { + "search": "mot", + "suggesterName": "sg" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "137", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:51:20 GMT", + "elapsed-time": "45", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a58ce1e7-7fc3-11ec-9abe-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.text": "Cheapest hotel in town. Infact, a motel.", + "hotelId": "2" + }, + { + "@search.text": "Secret Point Motel", + "hotelId": "9" + } + ] + } + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_index_client_data_source_live_async.pyTestSearchClientDataSourcesAsynctest_data_source.json b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_index_client_data_source_live_async.pyTestSearchClientDataSourcesAsynctest_data_source.json new file mode 100644 index 000000000000..4dde7f2aa2ef --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_index_client_data_source_live_async.pyTestSearchClientDataSourcesAsynctest_data_source.json @@ -0,0 +1,1305 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "226", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "91916008-7fc3-11ec-b96d-74c63bed1137" + }, + "RequestBody": { + "name": "create", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "400", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:47 GMT", + "elapsed-time": "35", + "ETag": "W/\u00220x8D9E1E775E9F68A\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027create\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "91916008-7fc3-11ec-b96d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E775E9F68A\u0022", + "name": "create", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "226", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "91ef693c-7fc3-11ec-8d5f-74c63bed1137" + }, + "RequestBody": { + "name": "delete", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "400", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:48 GMT", + "elapsed-time": "36", + "ETag": "W/\u00220x8D9E1E776020EDE\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027delete\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "91ef693c-7fc3-11ec-8d5f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E776020EDE\u0022", + "name": "delete", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "92057abe-7fc3-11ec-94ff-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "710", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:48 GMT", + "elapsed-time": "19", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "92057abe-7fc3-11ec-94ff-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E775E9F68A\u0022", + "name": "create", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E776020EDE\u0022", + "name": "delete", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources(\u0027delete\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "921892e3-7fc3-11ec-9d49-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:50:48 GMT", + "elapsed-time": "23", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "921892e3-7fc3-11ec-9d49-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "922b59ec-7fc3-11ec-b7c3-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "404", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:48 GMT", + "elapsed-time": "11", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "922b59ec-7fc3-11ec-b7c3-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E775E9F68A\u0022", + "name": "create", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "223", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "923c4be0-7fc3-11ec-a05f-74c63bed1137" + }, + "RequestBody": { + "name": "get", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "397", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:48 GMT", + "elapsed-time": "34", + "ETag": "W/\u00220x8D9E1E7764F3914\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027get\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "923c4be0-7fc3-11ec-a05f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E7764F3914\u0022", + "name": "get", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources(\u0027get\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "92521432-7fc3-11ec-ac68-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "397", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:48 GMT", + "elapsed-time": "8", + "ETag": "W/\u00220x8D9E1E7764F3914\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "92521432-7fc3-11ec-ac68-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E7764F3914\u0022", + "name": "get", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "224", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "9263a13c-7fc3-11ec-a26c-74c63bed1137" + }, + "RequestBody": { + "name": "list", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "398", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:48 GMT", + "elapsed-time": "42", + "ETag": "W/\u00220x8D9E1E77677067F\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027list\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "9263a13c-7fc3-11ec-a26c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E77677067F\u0022", + "name": "list", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "225", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "927b3e8e-7fc3-11ec-9c06-74c63bed1137" + }, + "RequestBody": { + "name": "list2", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "399", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:48 GMT", + "elapsed-time": "39", + "ETag": "W/\u00220x8D9E1E776942726\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027list2\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "927b3e8e-7fc3-11ec-9c06-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E776942726\u0022", + "name": "list2", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "92972068-7fc3-11ec-a515-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1316", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:49 GMT", + "elapsed-time": "28", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "92972068-7fc3-11ec-a515-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E775E9F68A\u0022", + "name": "create", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E7764F3914\u0022", + "name": "get", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E77677067F\u0022", + "name": "list", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E776942726\u0022", + "name": "list2", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "223", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "92ae200c-7fc3-11ec-b748-74c63bed1137" + }, + "RequestBody": { + "name": "cou", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "397", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:49 GMT", + "elapsed-time": "39", + "ETag": "W/\u00220x8D9E1E776C875D9\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027cou\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "92ae200c-7fc3-11ec-b748-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E776C875D9\u0022", + "name": "cou", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "92cbb99f-7fc3-11ec-b58c-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1619", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:49 GMT", + "elapsed-time": "33", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "92cbb99f-7fc3-11ec-b58c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E776C875D9\u0022", + "name": "cou", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E775E9F68A\u0022", + "name": "create", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E7764F3914\u0022", + "name": "get", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E77677067F\u0022", + "name": "list", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E776942726\u0022", + "name": "list2", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources(\u0027cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "249", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "92e32a26-7fc3-11ec-956d-74c63bed1137" + }, + "RequestBody": { + "name": "cou", + "description": "updated", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "402", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:49 GMT", + "elapsed-time": "32", + "ETag": "W/\u00220x8D9E1E776FCEB91\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "92e32a26-7fc3-11ec-956d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E776FCEB91\u0022", + "name": "cou", + "description": "updated", + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "92ffe713-7fc3-11ec-af38-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1624", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:49 GMT", + "elapsed-time": "31", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "92ffe713-7fc3-11ec-af38-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E776FCEB91\u0022", + "name": "cou", + "description": "updated", + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E775E9F68A\u0022", + "name": "create", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E7764F3914\u0022", + "name": "get", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E77677067F\u0022", + "name": "list", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E776942726\u0022", + "name": "list2", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources(\u0027cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "93151551-7fc3-11ec-a22a-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "402", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:49 GMT", + "elapsed-time": "7", + "ETag": "W/\u00220x8D9E1E776FCEB91\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "93151551-7fc3-11ec-a22a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E776FCEB91\u0022", + "name": "cou", + "description": "updated", + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "227", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "932568e5-7fc3-11ec-b1fe-74c63bed1137" + }, + "RequestBody": { + "name": "couunch", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "401", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:49 GMT", + "elapsed-time": "37", + "ETag": "W/\u00220x8D9E1E777383E18\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027couunch\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "932568e5-7fc3-11ec-b1fe-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E777383E18\u0022", + "name": "couunch", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources(\u0027couunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "253", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "933b1b8f-7fc3-11ec-aeb1-74c63bed1137" + }, + "RequestBody": { + "name": "couunch", + "description": "updated", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "406", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:50 GMT", + "elapsed-time": "52", + "ETag": "W/\u00220x8D9E1E777570C32\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "933b1b8f-7fc3-11ec-aeb1-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E777570C32\u0022", + "name": "couunch", + "description": "updated", + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources(\u0027couunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "293", + "Content-Type": "application/json", + "If-Match": "\u00220x8D9E1E777383E18\u0022", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "9359ee76-7fc3-11ec-8faf-74c63bed1137" + }, + "RequestBody": { + "name": "couunch", + "description": "changed", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + }, + "@odata.etag": "\u00220x8D9E1E777383E18\u0022" + }, + "StatusCode": 412, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "160", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:50 GMT", + "elapsed-time": "8", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "9359ee76-7fc3-11ec-8faf-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "The precondition given in one of the request headers evaluated to false. No change was made to the resource from this request." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "227", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "93729e13-7fc3-11ec-8047-74c63bed1137" + }, + "RequestBody": { + "name": "delunch", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "401", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:50 GMT", + "elapsed-time": "36", + "ETag": "W/\u00220x8D9E1E7778B33D5\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027delunch\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "93729e13-7fc3-11ec-8047-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E7778B33D5\u0022", + "name": "delunch", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources(\u0027delunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "253", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "938e13d8-7fc3-11ec-b222-74c63bed1137" + }, + "RequestBody": { + "name": "delunch", + "description": "updated", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "406", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:50 GMT", + "elapsed-time": "30", + "ETag": "W/\u00220x8D9E1E7779FA333\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "938e13d8-7fc3-11ec-b222-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E7779FA333\u0022", + "name": "delunch", + "description": "updated", + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources(\u0027delunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "If-Match": "\u00220x8D9E1E7778B33D5\u0022", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "93a25b8f-7fc3-11ec-8ab7-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 412, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "160", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:50 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "93a25b8f-7fc3-11ec-8ab7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "The precondition given in one of the request headers evaluated to false. No change was made to the resource from this request." + } + } + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_index_client_live_async.pyTestSearchIndexClientAsynctest_search_index_client.json b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_index_client_live_async.pyTestSearchIndexClientAsynctest_search_index_client.json new file mode 100644 index 000000000000..598cadb416aa --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_index_client_live_async.pyTestSearchIndexClientAsynctest_search_index_client.json @@ -0,0 +1,1677 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/servicestats?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "845193fc-7fc3-11ec-88ac-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "590", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:25 GMT", + "elapsed-time": "23", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "845193fc-7fc3-11ec-88ac-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#Microsoft.Azure.Search.V2021_04_30_Preview.ServiceStatistics", + "counters": { + "documentCount": { + "usage": 0, + "quota": null + }, + "indexesCount": { + "usage": 0, + "quota": 50 + }, + "indexersCount": { + "usage": 0, + "quota": 50 + }, + "dataSourcesCount": { + "usage": 0, + "quota": 50 + }, + "storageSize": { + "usage": 0, + "quota": 26843545600 + }, + "synonymMaps": { + "usage": 0, + "quota": 5 + }, + "skillsetCount": { + "usage": 0, + "quota": 50 + } + }, + "limits": { + "maxFieldsPerIndex": 3000, + "maxFieldNestingDepthPerIndex": 10, + "maxComplexCollectionFieldsPerIndex": 40, + "maxComplexObjectsInCollectionsPerDocument": 3000 + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "84b2c009-7fc3-11ec-a78f-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "95", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:25 GMT", + "elapsed-time": "19", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "84b2c009-7fc3-11ec-a78f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes", + "value": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "457", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "84c5b673-7fc3-11ec-8b9b-74c63bed1137" + }, + "RequestBody": { + "name": "hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false, + "filterable": false, + "sortable": false, + "facetable": false + }, + { + "name": "baseRate", + "type": "Edm.Double", + "key": false, + "retrievable": true, + "searchable": false, + "filterable": false, + "sortable": false, + "facetable": false + } + ], + "scoringProfiles": [ + { + "name": "MyProfile" + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "1040", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:26 GMT", + "elapsed-time": "556", + "ETag": "W/\u00220x8D9E1E76926F2BB\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "84c5b673-7fc3-11ec-8b9b-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E76926F2BB\u0022", + "name": "hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [ + { + "name": "MyProfile", + "functionAggregation": null, + "text": null, + "functions": [] + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "852a279d-7fc3-11ec-836f-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1044", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:26 GMT", + "elapsed-time": "34", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "852a279d-7fc3-11ec-836f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E76926F2BB\u0022", + "name": "hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [ + { + "name": "MyProfile", + "functionAggregation": null, + "text": null, + "functions": [] + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "853ec3d2-7fc3-11ec-8883-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1040", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:26 GMT", + "elapsed-time": "17", + "ETag": "W/\u00220x8D9E1E76926F2BB\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "853ec3d2-7fc3-11ec-8883-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E76926F2BB\u0022", + "name": "hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [ + { + "name": "MyProfile", + "functionAggregation": null, + "text": null, + "functions": [] + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels\u0027)/search.stats?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "85510f1d-7fc3-11ec-b52c-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "169", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:26 GMT", + "elapsed-time": "15", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "85510f1d-7fc3-11ec-b52c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#Microsoft.Azure.Search.V2021_04_30_Preview.IndexStatistics", + "documentCount": 0, + "storageSize": 0 + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "316", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "8563d777-7fc3-11ec-a86e-74c63bed1137" + }, + "RequestBody": { + "name": "hotels-del-unchanged", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + }, + { + "name": "baseRate", + "type": "Edm.Double", + "retrievable": true + } + ], + "scoringProfiles": [ + { + "name": "MyProfile" + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "1048", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:27 GMT", + "elapsed-time": "644", + "ETag": "W/\u00220x8D9E1E769D36D16\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-del-unchanged\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "8563d777-7fc3-11ec-a86e-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E769D36D16\u0022", + "name": "hotels-del-unchanged", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [ + { + "name": "MyProfile", + "functionAggregation": null, + "text": null, + "functions": [] + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-del-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "295", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "85d697c9-7fc3-11ec-a6c6-74c63bed1137" + }, + "RequestBody": { + "name": "hotels-del-unchanged", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + }, + { + "name": "baseRate", + "type": "Edm.Double", + "retrievable": true + } + ], + "scoringProfiles": [], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + } + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "974", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:27 GMT", + "elapsed-time": "165", + "ETag": "W/\u00220x8D9E1E769FC99EA\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "85d697c9-7fc3-11ec-a6c6-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E769FC99EA\u0022", + "name": "hotels-del-unchanged", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-del-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "If-Match": "\u00220x8D9E1E769D36D16\u0022", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "85ffc473-7fc3-11ec-b1d5-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 412, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "160", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:27 GMT", + "elapsed-time": "39", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "85ffc473-7fc3-11ec-b1d5-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "The precondition given in one of the request headers evaluated to false. No change was made to the resource from this request." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "440", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "86156d13-7fc3-11ec-bfbb-74c63bed1137" + }, + "RequestBody": { + "name": "hotels-cou", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false, + "filterable": false, + "sortable": false, + "facetable": false + }, + { + "name": "baseRate", + "type": "Edm.Double", + "key": false, + "retrievable": true, + "searchable": false, + "filterable": false, + "sortable": false, + "facetable": false + } + ], + "scoringProfiles": [], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "970", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:28 GMT", + "elapsed-time": "571", + "ETag": "W/\u00220x8D9E1E76A78E39C\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-cou\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "86156d13-7fc3-11ec-bfbb-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E76A78E39C\u0022", + "name": "hotels-cou", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "461", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "867c44dc-7fc3-11ec-b6e2-74c63bed1137" + }, + "RequestBody": { + "name": "hotels-cou", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false, + "filterable": false, + "sortable": false, + "facetable": false + }, + { + "name": "baseRate", + "type": "Edm.Double", + "key": false, + "retrievable": true, + "searchable": false, + "filterable": false, + "sortable": false, + "facetable": false + } + ], + "scoringProfiles": [ + { + "name": "MyProfile" + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + } + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1044", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:28 GMT", + "elapsed-time": "159", + "ETag": "W/\u00220x8D9E1E76A9F9FCA\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "867c44dc-7fc3-11ec-b6e2-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E76A9F9FCA\u0022", + "name": "hotels-cou", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [ + { + "name": "MyProfile", + "functionAggregation": null, + "text": null, + "functions": [] + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "316", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "86a5737e-7fc3-11ec-90a9-74c63bed1137" + }, + "RequestBody": { + "name": "hotels-coa-unchanged", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + }, + { + "name": "baseRate", + "type": "Edm.Double", + "retrievable": true + } + ], + "scoringProfiles": [ + { + "name": "MyProfile" + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "1048", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:29 GMT", + "elapsed-time": "658", + "ETag": "W/\u00220x8D9E1E76B16BA1C\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-coa-unchanged\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "86a5737e-7fc3-11ec-90a9-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E76B16BA1C\u0022", + "name": "hotels-coa-unchanged", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [ + { + "name": "MyProfile", + "functionAggregation": null, + "text": null, + "functions": [] + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-coa-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "295", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "871a1007-7fc3-11ec-8c8d-74c63bed1137" + }, + "RequestBody": { + "name": "hotels-coa-unchanged", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + }, + { + "name": "baseRate", + "type": "Edm.Double", + "retrievable": true + } + ], + "scoringProfiles": [], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + } + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "974", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:29 GMT", + "elapsed-time": "148", + "ETag": "W/\u00220x8D9E1E76B3E397B\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "871a1007-7fc3-11ec-8c8d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E76B3E397B\u0022", + "name": "hotels-coa-unchanged", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-coa-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "335", + "Content-Type": "application/json", + "If-Match": "\u00220x8D9E1E76B16BA1C\u0022", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "874184ec-7fc3-11ec-a123-74c63bed1137" + }, + "RequestBody": { + "name": "hotels-coa-unchanged", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + }, + { + "name": "baseRate", + "type": "Edm.Double", + "retrievable": true + } + ], + "scoringProfiles": [], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "@odata.etag": "\u00220x8D9E1E76B16BA1C\u0022" + }, + "StatusCode": 412, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "160", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:29 GMT", + "elapsed-time": "18", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "874184ec-7fc3-11ec-a123-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "The precondition given in one of the request headers evaluated to false. No change was made to the resource from this request." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels\u0027)/search.analyze?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "55", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "87548b8a-7fc3-11ec-b3c2-74c63bed1137" + }, + "RequestBody": { + "text": "One\u0027s \u003Ctwo/\u003E", + "analyzer": "standard.lucene" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "265", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:29 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "87548b8a-7fc3-11ec-b3c2-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#Microsoft.Azure.Search.V2021_04_30_Preview.AnalyzeResult", + "tokens": [ + { + "token": "one\u0027s", + "startOffset": 0, + "endOffset": 5, + "position": 0 + }, + { + "token": "two", + "startOffset": 7, + "endOffset": 10, + "position": 1 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "8768918f-7fc3-11ec-ac61-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "3766", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:50:29 GMT", + "elapsed-time": "95", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "8768918f-7fc3-11ec-ac61-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E76B3E397B\u0022", + "name": "hotels-coa-unchanged", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + }, + { + "@odata.etag": "\u00220x8D9E1E76A9F9FCA\u0022", + "name": "hotels-cou", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [ + { + "name": "MyProfile", + "functionAggregation": null, + "text": null, + "functions": [] + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + }, + { + "@odata.etag": "\u00220x8D9E1E769FC99EA\u0022", + "name": "hotels-del-unchanged", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + }, + { + "@odata.etag": "\u00220x8D9E1E76926F2BB\u0022", + "name": "hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [ + { + "name": "MyProfile", + "functionAggregation": null, + "text": null, + "functions": [] + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-coa-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "87876d2f-7fc3-11ec-88b0-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:50:29 GMT", + "elapsed-time": "158", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "87876d2f-7fc3-11ec-88b0-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "87af7452-7fc3-11ec-bdee-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:50:31 GMT", + "elapsed-time": "140", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "87af7452-7fc3-11ec-bdee-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-del-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "87d57974-7fc3-11ec-8407-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:50:31 GMT", + "elapsed-time": "143", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "87d57974-7fc3-11ec-8407-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "87fb3db8-7fc3-11ec-8860-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:50:31 GMT", + "elapsed-time": "138", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "87fb3db8-7fc3-11ec-8860-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_index_client_skillset_live_async.pyTestSearchClientSkillsetstest_skillset_crud.json b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_index_client_skillset_live_async.pyTestSearchClientSkillsetstest_skillset_crud.json new file mode 100644 index 000000000000..67159d8e477d --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_index_client_skillset_live_async.pyTestSearchClientSkillsetstest_skillset_crud.json @@ -0,0 +1,1866 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "1218", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6aa87b75-7fc3-11ec-9f80-74c63bed1137" + }, + "RequestBody": { + "name": "test-ss-create", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "skill1", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS1" + } + ], + "includeTypelessEntities": true + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityRecognitionSkill", + "name": "skill2", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS2" + } + ], + "modelVersion": "3" + }, + { + "@odata.type": "#Microsoft.Skills.Text.SentimentSkill", + "name": "skill3", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "score", + "targetName": "scoreS3" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.SentimentSkill", + "name": "skill4", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "confidenceScores", + "targetName": "scoreS4" + } + ], + "includeOpinionMining": true + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityLinkingSkill", + "name": "skill5", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "entities", + "targetName": "entitiesS5" + } + ], + "minimumPrecision": 0.5 + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "1925", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:41 GMT", + "elapsed-time": "46", + "ETag": "W/\u00220x8D9E1E74F05D2EC\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6aa87b75-7fc3-11ec-9f80-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#skillsets/$entity", + "@odata.etag": "\u00220x8D9E1E74F05D2EC\u0022", + "name": "test-ss-create", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "skill1", + "description": null, + "context": null, + "categories": [], + "defaultLanguageCode": null, + "minimumPrecision": null, + "includeTypelessEntities": true, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS1" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityRecognitionSkill", + "name": "skill2", + "description": null, + "context": null, + "categories": [], + "defaultLanguageCode": null, + "minimumPrecision": null, + "modelVersion": "3", + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS2" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.SentimentSkill", + "name": "skill3", + "description": null, + "context": null, + "defaultLanguageCode": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "score", + "targetName": "scoreS3" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.SentimentSkill", + "name": "skill4", + "description": null, + "context": null, + "defaultLanguageCode": null, + "modelVersion": null, + "includeOpinionMining": true, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "confidenceScores", + "targetName": "scoreS4" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityLinkingSkill", + "name": "skill5", + "description": null, + "context": null, + "defaultLanguageCode": null, + "minimumPrecision": 0.5, + "modelVersion": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "entities", + "targetName": "entitiesS5" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6b10352b-7fc3-11ec-b483-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "2179", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:43 GMT", + "elapsed-time": "26", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6b10352b-7fc3-11ec-b483-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#skillsets", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E74F05D2EC\u0022", + "name": "test-ss-create", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "skill1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": true, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS1" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityRecognitionSkill", + "name": "skill2", + "description": null, + "context": "/document", + "categories": [ + "Product", + "PhoneNumber", + "Person", + "Quantity", + "Organization", + "IPAddress", + "URL", + "Email", + "Event", + "Skill", + "Location", + "PersonType", + "Address", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "modelVersion": "3", + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS2" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.SentimentSkill", + "name": "skill3", + "description": null, + "context": "/document", + "defaultLanguageCode": "en", + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "score", + "targetName": "scoreS3" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.SentimentSkill", + "name": "skill4", + "description": null, + "context": "/document", + "defaultLanguageCode": "en", + "modelVersion": null, + "includeOpinionMining": true, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "confidenceScores", + "targetName": "scoreS4" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityLinkingSkill", + "name": "skill5", + "description": null, + "context": "/document", + "defaultLanguageCode": "en", + "minimumPrecision": 0.5, + "modelVersion": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "entities", + "targetName": "entitiesS5" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create\u0027)/search.resetskills?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "66", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6b2720e9-7fc3-11ec-b19b-74c63bed1137" + }, + "RequestBody": { + "skillNames": [ + "skill1", + "skill2", + "skill3", + "skill4", + "skill5" + ] + }, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:49:43 GMT", + "elapsed-time": "20", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "6b2720e9-7fc3-11ec-b19b-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "256", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6b3b94b8-7fc3-11ec-a431-74c63bed1137" + }, + "RequestBody": { + "name": "test-ss-get", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "616", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:43 GMT", + "elapsed-time": "39", + "ETag": "W/\u00220x8D9E1E74F4EDF28\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-get\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6b3b94b8-7fc3-11ec-a431-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#skillsets/$entity", + "@odata.etag": "\u00220x8D9E1E74F4EDF28\u0022", + "name": "test-ss-get", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": null, + "description": null, + "context": null, + "categories": [], + "defaultLanguageCode": null, + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-get\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6b526468-7fc3-11ec-95f4-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "693", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:43 GMT", + "elapsed-time": "13", + "ETag": "W/\u00220x8D9E1E74F4EDF28\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6b526468-7fc3-11ec-95f4-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#skillsets/$entity", + "@odata.etag": "\u00220x8D9E1E74F4EDF28\u0022", + "name": "test-ss-get", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "#1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "260", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6b65e8f9-7fc3-11ec-9c40-74c63bed1137" + }, + "RequestBody": { + "name": "test-ss-list-1", + "description": "desc1", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "620", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:43 GMT", + "elapsed-time": "39", + "ETag": "W/\u00220x8D9E1E74F79444D\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-list-1\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6b65e8f9-7fc3-11ec-9c40-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#skillsets/$entity", + "@odata.etag": "\u00220x8D9E1E74F79444D\u0022", + "name": "test-ss-list-1", + "description": "desc1", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": null, + "description": null, + "context": null, + "categories": [], + "defaultLanguageCode": null, + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "260", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6b7c8065-7fc3-11ec-b64b-74c63bed1137" + }, + "RequestBody": { + "name": "test-ss-list-2", + "description": "desc2", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "620", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:43 GMT", + "elapsed-time": "39", + "ETag": "W/\u00220x8D9E1E74F8F611F\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-list-2\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6b7c8065-7fc3-11ec-b64b-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#skillsets/$entity", + "@odata.etag": "\u00220x8D9E1E74F8F611F\u0022", + "name": "test-ss-list-2", + "description": "desc2", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": null, + "description": null, + "context": null, + "categories": [], + "defaultLanguageCode": null, + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6b92c50c-7fc3-11ec-9416-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "3990", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:43 GMT", + "elapsed-time": "42", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6b92c50c-7fc3-11ec-9416-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#skillsets", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E74F05D2EC\u0022", + "name": "test-ss-create", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "skill1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": true, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS1" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityRecognitionSkill", + "name": "skill2", + "description": null, + "context": "/document", + "categories": [ + "Product", + "PhoneNumber", + "Person", + "Quantity", + "Organization", + "IPAddress", + "URL", + "Email", + "Event", + "Skill", + "Location", + "PersonType", + "Address", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "modelVersion": "3", + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS2" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.SentimentSkill", + "name": "skill3", + "description": null, + "context": "/document", + "defaultLanguageCode": "en", + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "score", + "targetName": "scoreS3" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.SentimentSkill", + "name": "skill4", + "description": null, + "context": "/document", + "defaultLanguageCode": "en", + "modelVersion": null, + "includeOpinionMining": true, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "confidenceScores", + "targetName": "scoreS4" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityLinkingSkill", + "name": "skill5", + "description": null, + "context": "/document", + "defaultLanguageCode": "en", + "minimumPrecision": 0.5, + "modelVersion": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "entities", + "targetName": "entitiesS5" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E74F4EDF28\u0022", + "name": "test-ss-get", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "#1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E74F79444D\u0022", + "name": "test-ss-list-1", + "description": "desc1", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "#1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E74F8F611F\u0022", + "name": "test-ss-list-2", + "description": "desc2", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "#1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create-or-update-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "280", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6bab08ad-7fc3-11ec-81f5-74c63bed1137" + }, + "RequestBody": { + "name": "test-ss-create-or-update-unchanged", + "description": "desc1", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "640", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:44 GMT", + "elapsed-time": "38", + "ETag": "W/\u00220x8D9E1E74FBECE92\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create-or-update-unchanged\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6bab08ad-7fc3-11ec-81f5-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#skillsets/$entity", + "@odata.etag": "\u00220x8D9E1E74FBECE92\u0022", + "name": "test-ss-create-or-update-unchanged", + "description": "desc1", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": null, + "description": null, + "context": null, + "categories": [], + "defaultLanguageCode": null, + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create-or-update-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "320", + "Content-Type": "application/json", + "If-Match": "\u00220x8D9E1E74FBECE92\u0022", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6bc26633-7fc3-11ec-bfd7-74c63bed1137" + }, + "RequestBody": { + "name": "test-ss-create-or-update-unchanged", + "description": "desc2", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "@odata.etag": "\u00220x8D9E1E74FBECE92\u0022" + }, + "StatusCode": 500, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "56", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:44 GMT", + "elapsed-time": "14", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6bc26633-7fc3-11ec-bfd7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "An error has occurred." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create-or-update-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "320", + "Content-Type": "application/json", + "If-Match": "\u00220x8D9E1E74FBECE92\u0022", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6bc26633-7fc3-11ec-bfd7-74c63bed1137" + }, + "RequestBody": { + "name": "test-ss-create-or-update-unchanged", + "description": "desc2", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "@odata.etag": "\u00220x8D9E1E74FBECE92\u0022" + }, + "StatusCode": 500, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "56", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:44 GMT", + "elapsed-time": "13", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6bc26633-7fc3-11ec-bfd7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "An error has occurred." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create-or-update-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "320", + "Content-Type": "application/json", + "If-Match": "\u00220x8D9E1E74FBECE92\u0022", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6bc26633-7fc3-11ec-bfd7-74c63bed1137" + }, + "RequestBody": { + "name": "test-ss-create-or-update-unchanged", + "description": "desc2", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "@odata.etag": "\u00220x8D9E1E74FBECE92\u0022" + }, + "StatusCode": 500, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "56", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:46 GMT", + "elapsed-time": "17", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6bc26633-7fc3-11ec-bfd7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "An error has occurred." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create-or-update-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "320", + "Content-Type": "application/json", + "If-Match": "\u00220x8D9E1E74FBECE92\u0022", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6bc26633-7fc3-11ec-bfd7-74c63bed1137" + }, + "RequestBody": { + "name": "test-ss-create-or-update-unchanged", + "description": "desc2", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "@odata.etag": "\u00220x8D9E1E74FBECE92\u0022" + }, + "StatusCode": 500, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "56", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:49 GMT", + "elapsed-time": "14", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6bc26633-7fc3-11ec-bfd7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "An error has occurred." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6eed1241-7fc3-11ec-9fd8-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "4615", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:49 GMT", + "elapsed-time": "37", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6eed1241-7fc3-11ec-9fd8-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#skillsets", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E74FBECE92\u0022", + "name": "test-ss-create-or-update-unchanged", + "description": "desc1", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "#1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E74F05D2EC\u0022", + "name": "test-ss-create", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "skill1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": true, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS1" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityRecognitionSkill", + "name": "skill2", + "description": null, + "context": "/document", + "categories": [ + "Product", + "PhoneNumber", + "Person", + "Quantity", + "Organization", + "IPAddress", + "URL", + "Email", + "Event", + "Skill", + "Location", + "PersonType", + "Address", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "modelVersion": "3", + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS2" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.SentimentSkill", + "name": "skill3", + "description": null, + "context": "/document", + "defaultLanguageCode": "en", + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "score", + "targetName": "scoreS3" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.SentimentSkill", + "name": "skill4", + "description": null, + "context": "/document", + "defaultLanguageCode": "en", + "modelVersion": null, + "includeOpinionMining": true, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "confidenceScores", + "targetName": "scoreS4" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityLinkingSkill", + "name": "skill5", + "description": null, + "context": "/document", + "defaultLanguageCode": "en", + "minimumPrecision": 0.5, + "modelVersion": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "entities", + "targetName": "entitiesS5" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E74F4EDF28\u0022", + "name": "test-ss-get", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "#1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E74F79444D\u0022", + "name": "test-ss-list-1", + "description": "desc1", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "#1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E74F8F611F\u0022", + "name": "test-ss-list-2", + "description": "desc2", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "#1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create-or-update-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6f03cccb-7fc3-11ec-8f41-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:49:49 GMT", + "elapsed-time": "26", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "6f03cccb-7fc3-11ec-8f41-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6f187242-7fc3-11ec-adeb-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:49:49 GMT", + "elapsed-time": "31", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "6f187242-7fc3-11ec-adeb-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-get\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6f2dd324-7fc3-11ec-8faa-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:49:49 GMT", + "elapsed-time": "28", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "6f2dd324-7fc3-11ec-8faa-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-list-1\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6f42352f-7fc3-11ec-a2a6-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:49:49 GMT", + "elapsed-time": "28", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "6f42352f-7fc3-11ec-a2a6-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-list-2\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6f5789a4-7fc3-11ec-a4c5-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:49:49 GMT", + "elapsed-time": "25", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "6f5789a4-7fc3-11ec-a4c5-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_index_client_synonym_map_live_async.pyTestSearchClientSynonymMapstest_synonym_map.json b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_index_client_synonym_map_live_async.pyTestSearchClientSynonymMapstest_synonym_map.json new file mode 100644 index 000000000000..3dbd5ded7337 --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_index_client_synonym_map_live_async.pyTestSearchClientSynonymMapstest_synonym_map.json @@ -0,0 +1,1010 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "5e8669d7-7fc3-11ec-83ab-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "99", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:21 GMT", + "elapsed-time": "38", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "5e8669d7-7fc3-11ec-83ab-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "128", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "5eef4e8f-7fc3-11ec-ae41-74c63bed1137" + }, + "RequestBody": { + "name": "synmap-create", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA" + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "277", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:22 GMT", + "elapsed-time": "21", + "ETag": "W/\u00220x8D9E1E74302CE66\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-create\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "5eef4e8f-7fc3-11ec-ae41-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E74302CE66\u0022", + "name": "synmap-create", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "5f04badb-7fc3-11ec-93a3-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "281", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:22 GMT", + "elapsed-time": "12", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "5f04badb-7fc3-11ec-93a3-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E74302CE66\u0022", + "name": "synmap-create", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-create\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "5f18096b-7fc3-11ec-af95-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:49:22 GMT", + "elapsed-time": "302", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "5f18096b-7fc3-11ec-af95-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "125", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "5f572ff0-7fc3-11ec-a2c1-74c63bed1137" + }, + "RequestBody": { + "name": "synmap-del", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA" + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "274", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:22 GMT", + "elapsed-time": "61", + "ETag": "W/\u00220x8D9E1E7436F62F0\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-del\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "5f572ff0-7fc3-11ec-a2c1-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E7436F62F0\u0022", + "name": "synmap-del", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "5f71318c-7fc3-11ec-a8ab-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "278", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:22 GMT", + "elapsed-time": "12", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "5f71318c-7fc3-11ec-a8ab-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E7436F62F0\u0022", + "name": "synmap-del", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-del\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "5f83e86b-7fc3-11ec-bec3-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:49:22 GMT", + "elapsed-time": "12", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "5f83e86b-7fc3-11ec-bec3-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "5f967556-7fc3-11ec-9b65-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "99", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:23 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "5f967556-7fc3-11ec-9b65-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "129", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "5fa88744-7fc3-11ec-b95f-74c63bed1137" + }, + "RequestBody": { + "name": "synmap-delunch", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA" + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "278", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:23 GMT", + "elapsed-time": "38", + "ETag": "W/\u00220x8D9E1E743BDC582\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-delunch\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "5fa88744-7fc3-11ec-b95f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E743BDC582\u0022", + "name": "synmap-delunch", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-delunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "127", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "5fbf9693-7fc3-11ec-8fe4-74c63bed1137" + }, + "RequestBody": { + "name": "synmap-delunch", + "format": "solr", + "synonyms": "W\na\ns\nh\ni\nn\ng\nt\no\nn\n,\n \nW\na\ns\nh\n.\n \n=\n\u003E\n \nW\nA" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "276", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:23 GMT", + "elapsed-time": "27", + "ETag": "W/\u00220x8D9E1E743D51AB0\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "5fbf9693-7fc3-11ec-8fe4-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E743D51AB0\u0022", + "name": "synmap-delunch", + "format": "solr", + "synonyms": "W\na\ns\nh\ni\nn\ng\nt\no\nn\n,\n \nW\na\ns\nh\n.\n \n=\n\u003E\n \nW\nA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-delunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "If-Match": "\u00220x8D9E1E743BDC582\u0022", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "5fd71c34-7fc3-11ec-857f-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 412, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "160", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:23 GMT", + "elapsed-time": "8", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "5fd71c34-7fc3-11ec-857f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "The precondition given in one of the request headers evaluated to false. No change was made to the resource from this request." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-delunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "5fe92ef9-7fc3-11ec-80b3-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:49:23 GMT", + "elapsed-time": "13", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "5fe92ef9-7fc3-11ec-80b3-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "5ffd1454-7fc3-11ec-b78e-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "99", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:23 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "5ffd1454-7fc3-11ec-b78e-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "125", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "600f8c67-7fc3-11ec-84c1-74c63bed1137" + }, + "RequestBody": { + "name": "synmap-get", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA" + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "274", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:23 GMT", + "elapsed-time": "22", + "ETag": "W/\u00220x8D9E1E74421CFDE\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-get\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "600f8c67-7fc3-11ec-84c1-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E74421CFDE\u0022", + "name": "synmap-get", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6023cda8-7fc3-11ec-b02a-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "278", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:23 GMT", + "elapsed-time": "13", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6023cda8-7fc3-11ec-b02a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E74421CFDE\u0022", + "name": "synmap-get", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-get\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6036a25e-7fc3-11ec-9c4d-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "274", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:24 GMT", + "elapsed-time": "7", + "ETag": "W/\u00220x8D9E1E74421CFDE\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6036a25e-7fc3-11ec-9c4d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E74421CFDE\u0022", + "name": "synmap-get", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-get\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "60491d0b-7fc3-11ec-8aba-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:49:24 GMT", + "elapsed-time": "12", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "60491d0b-7fc3-11ec-8aba-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "127", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "605bd6a0-7fc3-11ec-ad69-74c63bed1137" + }, + "RequestBody": { + "name": "synmap-list1", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA" + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "276", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:24 GMT", + "elapsed-time": "25", + "ETag": "W/\u00220x8D9E1E7446F212B\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-list1\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "605bd6a0-7fc3-11ec-ad69-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E7446F212B\u0022", + "name": "synmap-list1", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "81", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6070f0cf-7fc3-11ec-ae66-74c63bed1137" + }, + "RequestBody": { + "name": "synmap-list2", + "format": "solr", + "synonyms": "Washington, Wash. =\u003E WA" + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "230", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:24 GMT", + "elapsed-time": "23", + "ETag": "W/\u00220x8D9E1E744839088\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-list2\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6070f0cf-7fc3-11ec-ae66-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E744839088\u0022", + "name": "synmap-list2", + "format": "solr", + "synonyms": "Washington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "60855f7e-7fc3-11ec-a8e5-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "416", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:24 GMT", + "elapsed-time": "18", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "60855f7e-7fc3-11ec-a8e5-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E7446F212B\u0022", + "name": "synmap-list1", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E744839088\u0022", + "name": "synmap-list2", + "format": "solr", + "synonyms": "Washington, Wash. =\u003E WA", + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-list1\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "609971aa-7fc3-11ec-8ad7-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:49:24 GMT", + "elapsed-time": "41", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "609971aa-7fc3-11ec-8ad7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-list2\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "60b19cce-7fc3-11ec-9246-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:49:24 GMT", + "elapsed-time": "13", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "60b19cce-7fc3-11ec-9246-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "60c5c4ee-7fc3-11ec-8abb-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "99", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:24 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "60c5c4ee-7fc3-11ec-8abb-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "125", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "60d7cad6-7fc3-11ec-87fc-74c63bed1137" + }, + "RequestBody": { + "name": "synmap-cou", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA" + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "274", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:26 GMT", + "elapsed-time": "40", + "ETag": "W/\u00220x8D9E1E744F3CE0E\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-cou\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "60d7cad6-7fc3-11ec-87fc-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E744F3CE0E\u0022", + "name": "synmap-cou", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "60f8d047-7fc3-11ec-8d83-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "278", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:26 GMT", + "elapsed-time": "13", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "60f8d047-7fc3-11ec-8d83-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E744F3CE0E\u0022", + "name": "synmap-cou", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "79", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "610bb66b-7fc3-11ec-baca-74c63bed1137" + }, + "RequestBody": { + "name": "synmap-cou", + "format": "solr", + "synonyms": "Washington, Wash. =\u003E WA" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "228", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:26 GMT", + "elapsed-time": "21", + "ETag": "W/\u00220x8D9E1E745258521\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "610bb66b-7fc3-11ec-baca-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E745258521\u0022", + "name": "synmap-cou", + "format": "solr", + "synonyms": "Washington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6127eb91-7fc3-11ec-bc45-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "232", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:26 GMT", + "elapsed-time": "12", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6127eb91-7fc3-11ec-bc45-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E745258521\u0022", + "name": "synmap-cou", + "format": "solr", + "synonyms": "Washington, Wash. =\u003E WA", + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "613b49eb-7fc3-11ec-8515-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "228", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:49:26 GMT", + "elapsed-time": "7", + "ETag": "W/\u00220x8D9E1E745258521\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "613b49eb-7fc3-11ec-8515-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E745258521\u0022", + "name": "synmap-cou", + "format": "solr", + "synonyms": "Washington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "614cd23a-7fc3-11ec-93d3-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:49:26 GMT", + "elapsed-time": "12", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "614cd23a-7fc3-11ec-93d3-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_indexer_client_live_async.pyTestSearchIndexerClientTestAsynctest_search_indexers.json b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_indexer_client_live_async.pyTestSearchIndexerClientTestAsynctest_search_indexers.json new file mode 100644 index 000000000000..5c94b36058f2 --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/async_tests/test_search_indexer_client_live_async.pyTestSearchIndexerClientTestAsynctest_search_indexers.json @@ -0,0 +1,3019 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "234", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3a184893-7fc3-11ec-9ea4-74c63bed1137" + }, + "RequestBody": { + "name": "create-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "408", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:21 GMT", + "elapsed-time": "45", + "ETag": "W/\u00220x8D9E1E71E75D6D3\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027create-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3a184893-7fc3-11ec-9ea4-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E71E75D6D3\u0022", + "name": "create-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "135", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3a7f6fbc-7fc3-11ec-80a7-74c63bed1137" + }, + "RequestBody": { + "name": "create-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "691", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:21 GMT", + "elapsed-time": "525", + "ETag": "W/\u00220x8D9E1E71EE15A21\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027create-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3a7f6fbc-7fc3-11ec-80a7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E71EE15A21\u0022", + "name": "create-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "104", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3ae41c70-7fc3-11ec-83f4-74c63bed1137" + }, + "RequestBody": { + "name": "create", + "dataSourceName": "create-ds", + "targetIndexName": "create-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "378", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:23 GMT", + "elapsed-time": "913", + "ETag": "W/\u00220x8D9E1E71F651CC2\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027create\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3ae41c70-7fc3-11ec-83f4-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E71F651CC2\u0022", + "name": "create", + "description": null, + "dataSourceName": "create-ds", + "skillsetName": null, + "targetIndexName": "create-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "234", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3b80de1c-7fc3-11ec-899a-74c63bed1137" + }, + "RequestBody": { + "name": "delete-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "408", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:23 GMT", + "elapsed-time": "42", + "ETag": "W/\u00220x8D9E1E71F959B83\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027delete-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3b80de1c-7fc3-11ec-899a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E71F959B83\u0022", + "name": "delete-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "135", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3b9813c4-7fc3-11ec-b00d-74c63bed1137" + }, + "RequestBody": { + "name": "delete-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "691", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:23 GMT", + "elapsed-time": "708", + "ETag": "W/\u00220x8D9E1E72010D3ED\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027delete-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3b9813c4-7fc3-11ec-b00d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E72010D3ED\u0022", + "name": "delete-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "104", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3c1514e2-7fc3-11ec-942d-74c63bed1137" + }, + "RequestBody": { + "name": "delete", + "dataSourceName": "delete-ds", + "targetIndexName": "delete-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "378", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:24 GMT", + "elapsed-time": "462", + "ETag": "W/\u00220x8D9E1E7205573F9\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027delete\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3c1514e2-7fc3-11ec-942d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E7205573F9\u0022", + "name": "delete", + "description": null, + "dataSourceName": "delete-ds", + "skillsetName": null, + "targetIndexName": "delete-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3c6cc43c-7fc3-11ec-a814-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "669", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:24 GMT", + "elapsed-time": "40", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3c6cc43c-7fc3-11ec-a814-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E71F651CC2\u0022", + "name": "create", + "description": null, + "dataSourceName": "create-ds", + "skillsetName": null, + "targetIndexName": "create-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E7205573F9\u0022", + "name": "delete", + "description": null, + "dataSourceName": "delete-ds", + "skillsetName": null, + "targetIndexName": "delete-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027delete\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3c844881-7fc3-11ec-a44c-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:48:24 GMT", + "elapsed-time": "39", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "3c844881-7fc3-11ec-a44c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3c9ae136-7fc3-11ec-904d-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "382", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:24 GMT", + "elapsed-time": "30", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3c9ae136-7fc3-11ec-904d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E71F651CC2\u0022", + "name": "create", + "description": null, + "dataSourceName": "create-ds", + "skillsetName": null, + "targetIndexName": "create-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "231", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3cb046a2-7fc3-11ec-8de5-74c63bed1137" + }, + "RequestBody": { + "name": "get-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "405", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:24 GMT", + "elapsed-time": "46", + "ETag": "W/\u00220x8D9E1E720C4EE47\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027get-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3cb046a2-7fc3-11ec-8de5-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E720C4EE47\u0022", + "name": "get-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "132", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3cc79b1f-7fc3-11ec-ac18-74c63bed1137" + }, + "RequestBody": { + "name": "get-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "688", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:26 GMT", + "elapsed-time": "603", + "ETag": "W/\u00220x8D9E1E72132460A\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027get-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3cc79b1f-7fc3-11ec-ac18-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E72132460A\u0022", + "name": "get-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "95", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3d351f6c-7fc3-11ec-8274-74c63bed1137" + }, + "RequestBody": { + "name": "get", + "dataSourceName": "get-ds", + "targetIndexName": "get-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "369", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:26 GMT", + "elapsed-time": "456", + "ETag": "W/\u00220x8D9E1E721744E65\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027get\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3d351f6c-7fc3-11ec-8274-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E721744E65\u0022", + "name": "get", + "description": null, + "dataSourceName": "get-ds", + "skillsetName": null, + "targetIndexName": "get-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027get\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3d8b2e26-7fc3-11ec-8b2f-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "369", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:26 GMT", + "elapsed-time": "8", + "ETag": "W/\u00220x8D9E1E721744E65\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3d8b2e26-7fc3-11ec-8b2f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E721744E65\u0022", + "name": "get", + "description": null, + "dataSourceName": "get-ds", + "skillsetName": null, + "targetIndexName": "get-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "233", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3d9d2206-7fc3-11ec-a94a-74c63bed1137" + }, + "RequestBody": { + "name": "list1-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "407", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:26 GMT", + "elapsed-time": "44", + "ETag": "W/\u00220x8D9E1E721B1EA97\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027list1-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3d9d2206-7fc3-11ec-a94a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E721B1EA97\u0022", + "name": "list1-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "134", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3db4b772-7fc3-11ec-93e3-74c63bed1137" + }, + "RequestBody": { + "name": "list1-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "690", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:27 GMT", + "elapsed-time": "543", + "ETag": "W/\u00220x8D9E1E7221531B4\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027list1-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3db4b772-7fc3-11ec-93e3-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E7221531B4\u0022", + "name": "list1-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "233", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3e187de8-7fc3-11ec-b1aa-74c63bed1137" + }, + "RequestBody": { + "name": "list2-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "407", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:27 GMT", + "elapsed-time": "179", + "ETag": "W/\u00220x8D9E1E72242077D\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027list2-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3e187de8-7fc3-11ec-b1aa-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E72242077D\u0022", + "name": "list2-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "134", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3e451e84-7fc3-11ec-b0af-74c63bed1137" + }, + "RequestBody": { + "name": "list2-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "690", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:28 GMT", + "elapsed-time": "612", + "ETag": "W/\u00220x8D9E1E722B181CA\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027list2-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3e451e84-7fc3-11ec-b0af-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E722B181CA\u0022", + "name": "list2-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "101", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3eb54ef3-7fc3-11ec-af35-74c63bed1137" + }, + "RequestBody": { + "name": "list1", + "dataSourceName": "list1-ds", + "targetIndexName": "list1-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "375", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:28 GMT", + "elapsed-time": "499", + "ETag": "W/\u00220x8D9E1E722FC3B74\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027list1\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3eb54ef3-7fc3-11ec-af35-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E722FC3B74\u0022", + "name": "list1", + "description": null, + "dataSourceName": "list1-ds", + "skillsetName": null, + "targetIndexName": "list1-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "101", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3f13fad6-7fc3-11ec-9175-74c63bed1137" + }, + "RequestBody": { + "name": "list2", + "dataSourceName": "list2-ds", + "targetIndexName": "list2-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "375", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:29 GMT", + "elapsed-time": "454", + "ETag": "W/\u00220x8D9E1E72354FCC8\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027list2\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3f13fad6-7fc3-11ec-9175-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E72354FCC8\u0022", + "name": "list2", + "description": null, + "dataSourceName": "list2-ds", + "skillsetName": null, + "targetIndexName": "list2-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3f6aef77-7fc3-11ec-8032-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1228", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:29 GMT", + "elapsed-time": "24", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3f6aef77-7fc3-11ec-8032-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E71F651CC2\u0022", + "name": "create", + "description": null, + "dataSourceName": "create-ds", + "skillsetName": null, + "targetIndexName": "create-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E721744E65\u0022", + "name": "get", + "description": null, + "dataSourceName": "get-ds", + "skillsetName": null, + "targetIndexName": "get-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E722FC3B74\u0022", + "name": "list1", + "description": null, + "dataSourceName": "list1-ds", + "skillsetName": null, + "targetIndexName": "list1-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E72354FCC8\u0022", + "name": "list2", + "description": null, + "dataSourceName": "list2-ds", + "skillsetName": null, + "targetIndexName": "list2-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "231", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3f7fec11-7fc3-11ec-a941-74c63bed1137" + }, + "RequestBody": { + "name": "cou-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "405", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:29 GMT", + "elapsed-time": "54", + "ETag": "W/\u00220x8D9E1E72396DE25\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027cou-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3f7fec11-7fc3-11ec-a941-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E72396DE25\u0022", + "name": "cou-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "132", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "3f99be45-7fc3-11ec-a368-74c63bed1137" + }, + "RequestBody": { + "name": "cou-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "688", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:30 GMT", + "elapsed-time": "675", + "ETag": "W/\u00220x8D9E1E7240A9D8F\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027cou-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "3f99be45-7fc3-11ec-a368-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E7240A9D8F\u0022", + "name": "cou-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "95", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "40123acf-7fc3-11ec-82b7-74c63bed1137" + }, + "RequestBody": { + "name": "cou", + "dataSourceName": "cou-ds", + "targetIndexName": "cou-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "369", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:30 GMT", + "elapsed-time": "495", + "ETag": "W/\u00220x8D9E1E7245493FE\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027cou\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "40123acf-7fc3-11ec-82b7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E7245493FE\u0022", + "name": "cou", + "description": null, + "dataSourceName": "cou-ds", + "skillsetName": null, + "targetIndexName": "cou-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "406f2bc0-7fc3-11ec-97ee-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1506", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:30 GMT", + "elapsed-time": "33", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "406f2bc0-7fc3-11ec-97ee-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E7245493FE\u0022", + "name": "cou", + "description": null, + "dataSourceName": "cou-ds", + "skillsetName": null, + "targetIndexName": "cou-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E71F651CC2\u0022", + "name": "create", + "description": null, + "dataSourceName": "create-ds", + "skillsetName": null, + "targetIndexName": "create-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E721744E65\u0022", + "name": "get", + "description": null, + "dataSourceName": "get-ds", + "skillsetName": null, + "targetIndexName": "get-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E722FC3B74\u0022", + "name": "list1", + "description": null, + "dataSourceName": "list1-ds", + "skillsetName": null, + "targetIndexName": "list1-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E72354FCC8\u0022", + "name": "list2", + "description": null, + "dataSourceName": "list2-ds", + "skillsetName": null, + "targetIndexName": "list2-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "121", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "4085c460-7fc3-11ec-b4ad-74c63bed1137" + }, + "RequestBody": { + "name": "cou", + "description": "updated", + "dataSourceName": "cou-ds", + "targetIndexName": "cou-hotels", + "disabled": false + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "374", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:32 GMT", + "elapsed-time": "363", + "ETag": "W/\u00220x8D9E1E724CBAE50\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "4085c460-7fc3-11ec-b4ad-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E724CBAE50\u0022", + "name": "cou", + "description": "updated", + "dataSourceName": "cou-ds", + "skillsetName": null, + "targetIndexName": "cou-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "40ceb9a9-7fc3-11ec-9298-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1511", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:32 GMT", + "elapsed-time": "39", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "40ceb9a9-7fc3-11ec-9298-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E724CBAE50\u0022", + "name": "cou", + "description": "updated", + "dataSourceName": "cou-ds", + "skillsetName": null, + "targetIndexName": "cou-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E71F651CC2\u0022", + "name": "create", + "description": null, + "dataSourceName": "create-ds", + "skillsetName": null, + "targetIndexName": "create-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E721744E65\u0022", + "name": "get", + "description": null, + "dataSourceName": "get-ds", + "skillsetName": null, + "targetIndexName": "get-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E722FC3B74\u0022", + "name": "list1", + "description": null, + "dataSourceName": "list1-ds", + "skillsetName": null, + "targetIndexName": "list1-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E72354FCC8\u0022", + "name": "list2", + "description": null, + "dataSourceName": "list2-ds", + "skillsetName": null, + "targetIndexName": "list2-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "40e7c982-7fc3-11ec-985e-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "374", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:32 GMT", + "elapsed-time": "8", + "ETag": "W/\u00220x8D9E1E724CBAE50\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "40e7c982-7fc3-11ec-985e-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E724CBAE50\u0022", + "name": "cou", + "description": "updated", + "dataSourceName": "cou-ds", + "skillsetName": null, + "targetIndexName": "cou-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "233", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "40fad302-7fc3-11ec-bc51-74c63bed1137" + }, + "RequestBody": { + "name": "reset-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "407", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:32 GMT", + "elapsed-time": "61", + "ETag": "W/\u00220x8D9E1E72512E60B\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027reset-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "40fad302-7fc3-11ec-bc51-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E72512E60B\u0022", + "name": "reset-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "134", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "41162d67-7fc3-11ec-824d-74c63bed1137" + }, + "RequestBody": { + "name": "reset-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "690", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:33 GMT", + "elapsed-time": "643", + "ETag": "W/\u00220x8D9E1E7258741A1\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027reset-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "41162d67-7fc3-11ec-824d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E7258741A1\u0022", + "name": "reset-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "101", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "418a86fe-7fc3-11ec-b40c-74c63bed1137" + }, + "RequestBody": { + "name": "reset", + "dataSourceName": "reset-ds", + "targetIndexName": "reset-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "375", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:33 GMT", + "elapsed-time": "435", + "ETag": "W/\u00220x8D9E1E725C8FBF9\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027reset\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "418a86fe-7fc3-11ec-b40c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E725C8FBF9\u0022", + "name": "reset", + "description": null, + "dataSourceName": "reset-ds", + "skillsetName": null, + "targetIndexName": "reset-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027reset\u0027)/search.reset?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "41de1c2d-7fc3-11ec-b7ac-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:48:34 GMT", + "elapsed-time": "383", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "41de1c2d-7fc3-11ec-b7ac-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027reset\u0027)/search.status?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "4229ab0c-7fc3-11ec-8c29-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1039", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:34 GMT", + "elapsed-time": "13", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "4229ab0c-7fc3-11ec-8c29-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#Microsoft.Azure.Search.V2021_04_30_Preview.IndexerExecutionInfo", + "name": "reset", + "status": "running", + "lastResult": { + "status": "reset", + "statusDetail": null, + "errorMessage": null, + "startTime": "2022-01-27T22:48:33.981Z", + "endTime": "2022-01-27T22:48:33.981Z", + "itemsProcessed": 0, + "itemsFailed": 0, + "initialTrackingState": null, + "finalTrackingState": null, + "mode": "indexingAllDocs", + "errors": [], + "warnings": [], + "metrics": null + }, + "executionHistory": [ + { + "status": "reset", + "statusDetail": null, + "errorMessage": null, + "startTime": "2022-01-27T22:48:33.981Z", + "endTime": "2022-01-27T22:48:33.981Z", + "itemsProcessed": 0, + "itemsFailed": 0, + "initialTrackingState": null, + "finalTrackingState": null, + "mode": "indexingAllDocs", + "errors": [], + "warnings": [], + "metrics": null + } + ], + "limits": null, + "currentState": { + "mode": "indexingAllDocs", + "allDocsInitialTrackingState": null, + "allDocsFinalTrackingState": null, + "resetDocsInitialTrackingState": null, + "resetDocsFinalTrackingState": null, + "resetDocumentKeys": [], + "resetDatasourceDocumentIds": [] + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "231", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "423e2ac3-7fc3-11ec-8999-74c63bed1137" + }, + "RequestBody": { + "name": "run-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "405", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:34 GMT", + "elapsed-time": "59", + "ETag": "W/\u00220x8D9E1E726556FDC\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027run-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "423e2ac3-7fc3-11ec-8999-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E726556FDC\u0022", + "name": "run-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "132", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "4258d96b-7fc3-11ec-9c01-74c63bed1137" + }, + "RequestBody": { + "name": "run-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "688", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:34 GMT", + "elapsed-time": "546", + "ETag": "W/\u00220x8D9E1E726BA1657\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027run-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "4258d96b-7fc3-11ec-9c01-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E726BA1657\u0022", + "name": "run-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "95", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "42bd8d15-7fc3-11ec-bf85-74c63bed1137" + }, + "RequestBody": { + "name": "run", + "dataSourceName": "run-ds", + "targetIndexName": "run-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "369", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:35 GMT", + "elapsed-time": "421", + "ETag": "W/\u00220x8D9E1E726FA7147\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027run\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "42bd8d15-7fc3-11ec-bf85-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E726FA7147\u0022", + "name": "run", + "description": null, + "dataSourceName": "run-ds", + "skillsetName": null, + "targetIndexName": "run-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027run\u0027)/search.run?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "4310bc3b-7fc3-11ec-b585-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 202, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:48:35 GMT", + "elapsed-time": "33", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "4310bc3b-7fc3-11ec-b585-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027run\u0027)/search.status?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "4327e9da-7fc3-11ec-88d4-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "552", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:35 GMT", + "elapsed-time": "15", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "4327e9da-7fc3-11ec-88d4-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#Microsoft.Azure.Search.V2021_04_30_Preview.IndexerExecutionInfo", + "name": "run", + "status": "running", + "lastResult": null, + "executionHistory": [], + "limits": { + "maxRunTime": "PT0S", + "maxDocumentExtractionSize": 0, + "maxDocumentContentCharactersToExtract": 0 + }, + "currentState": { + "mode": "indexingAllDocs", + "allDocsInitialTrackingState": null, + "allDocsFinalTrackingState": null, + "resetDocsInitialTrackingState": null, + "resetDocsFinalTrackingState": null, + "resetDocumentKeys": [], + "resetDatasourceDocumentIds": [] + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "238", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "433baa05-7fc3-11ec-bfee-74c63bed1137" + }, + "RequestBody": { + "name": "get-status-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "412", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:35 GMT", + "elapsed-time": "67", + "ETag": "W/\u00220x8D9E1E72753F5CB\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027get-status-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "433baa05-7fc3-11ec-bfee-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E72753F5CB\u0022", + "name": "get-status-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "139", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "4356e379-7fc3-11ec-84ad-74c63bed1137" + }, + "RequestBody": { + "name": "get-status-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "695", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:37 GMT", + "elapsed-time": "605", + "ETag": "W/\u00220x8D9E1E727C1C2A9\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027get-status-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "4356e379-7fc3-11ec-84ad-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E727C1C2A9\u0022", + "name": "get-status-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "116", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "43c50d2c-7fc3-11ec-96dd-74c63bed1137" + }, + "RequestBody": { + "name": "get-status", + "dataSourceName": "get-status-ds", + "targetIndexName": "get-status-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "390", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:37 GMT", + "elapsed-time": "578", + "ETag": "W/\u00220x8D9E1E7281184A5\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027get-status\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "43c50d2c-7fc3-11ec-96dd-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E7281184A5\u0022", + "name": "get-status", + "description": null, + "dataSourceName": "get-status-ds", + "skillsetName": null, + "targetIndexName": "get-status-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027get-status\u0027)/search.status?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "442f3287-7fc3-11ec-acf5-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "559", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:37 GMT", + "elapsed-time": "16", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "442f3287-7fc3-11ec-acf5-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#Microsoft.Azure.Search.V2021_04_30_Preview.IndexerExecutionInfo", + "name": "get-status", + "status": "running", + "lastResult": null, + "executionHistory": [], + "limits": { + "maxRunTime": "PT0S", + "maxDocumentExtractionSize": 0, + "maxDocumentContentCharactersToExtract": 0 + }, + "currentState": { + "mode": "indexingAllDocs", + "allDocsInitialTrackingState": null, + "allDocsFinalTrackingState": null, + "resetDocsInitialTrackingState": null, + "resetDocsFinalTrackingState": null, + "resetDocumentKeys": [], + "resetDatasourceDocumentIds": [] + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "235", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "444347ff-7fc3-11ec-9b07-74c63bed1137" + }, + "RequestBody": { + "name": "couunch-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "409", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:38 GMT", + "elapsed-time": "60", + "ETag": "W/\u00220x8D9E1E7285B7B1B\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027couunch-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "444347ff-7fc3-11ec-9b07-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E7285B7B1B\u0022", + "name": "couunch-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "136", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "445e9f94-7fc3-11ec-967a-74c63bed1137" + }, + "RequestBody": { + "name": "couunch-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "692", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:38 GMT", + "elapsed-time": "614", + "ETag": "W/\u00220x8D9E1E728CB1C7A\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027couunch-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "445e9f94-7fc3-11ec-967a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E728CB1C7A\u0022", + "name": "couunch-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "107", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "44ceda64-7fc3-11ec-a39a-74c63bed1137" + }, + "RequestBody": { + "name": "couunch", + "dataSourceName": "couunch-ds", + "targetIndexName": "couunch-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "381", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:39 GMT", + "elapsed-time": "496", + "ETag": "W/\u00220x8D9E1E7290B023E\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027couunch\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "44ceda64-7fc3-11ec-a39a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E7290B023E\u0022", + "name": "couunch", + "description": null, + "dataSourceName": "couunch-ds", + "skillsetName": null, + "targetIndexName": "couunch-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027couunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "133", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "452c066c-7fc3-11ec-8089-74c63bed1137" + }, + "RequestBody": { + "name": "couunch", + "description": "updated", + "dataSourceName": "couunch-ds", + "targetIndexName": "couunch-hotels", + "disabled": false + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "386", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:39 GMT", + "elapsed-time": "302", + "ETag": "W/\u00220x8D9E1E72966D069\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "452c066c-7fc3-11ec-8089-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E72966D069\u0022", + "name": "couunch", + "description": "updated", + "dataSourceName": "couunch-ds", + "skillsetName": null, + "targetIndexName": "couunch-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027couunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "173", + "Content-Type": "application/json", + "If-Match": "\u00220x8D9E1E7290B023E\u0022", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "456c390b-7fc3-11ec-8009-74c63bed1137" + }, + "RequestBody": { + "name": "couunch", + "description": "updated", + "dataSourceName": "couunch-ds", + "targetIndexName": "couunch-hotels", + "disabled": false, + "@odata.etag": "\u00220x8D9E1E7290B023E\u0022" + }, + "StatusCode": 412, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "160", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:39 GMT", + "elapsed-time": "8", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "456c390b-7fc3-11ec-8009-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "The precondition given in one of the request headers evaluated to false. No change was made to the resource from this request." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "235", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "45803adf-7fc3-11ec-ba17-74c63bed1137" + }, + "RequestBody": { + "name": "delunch-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "409", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:39 GMT", + "elapsed-time": "62", + "ETag": "W/\u00220x8D9E1E729988776\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027delunch-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "45803adf-7fc3-11ec-ba17-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E729988776\u0022", + "name": "delunch-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "136", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "459ba274-7fc3-11ec-9741-74c63bed1137" + }, + "RequestBody": { + "name": "delunch-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "692", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:40 GMT", + "elapsed-time": "601", + "ETag": "W/\u00220x8D9E1E72A05430D\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027delunch-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "459ba274-7fc3-11ec-9741-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E72A05430D\u0022", + "name": "delunch-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "107", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "46088dfc-7fc3-11ec-b892-74c63bed1137" + }, + "RequestBody": { + "name": "delunch", + "dataSourceName": "delunch-ds", + "targetIndexName": "delunch-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "381", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:41 GMT", + "elapsed-time": "525", + "ETag": "W/\u00220x8D9E1E72A496E02\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027delunch\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "46088dfc-7fc3-11ec-b892-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E72A496E02\u0022", + "name": "delunch", + "description": null, + "dataSourceName": "delunch-ds", + "skillsetName": null, + "targetIndexName": "delunch-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027delunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "133", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "4669c10d-7fc3-11ec-b295-74c63bed1137" + }, + "RequestBody": { + "name": "delunch", + "description": "updated", + "dataSourceName": "delunch-ds", + "targetIndexName": "delunch-hotels", + "disabled": false + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "386", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:41 GMT", + "elapsed-time": "322", + "ETag": "W/\u00220x8D9E1E72AA6265B\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "4669c10d-7fc3-11ec-b295-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E72AA6265B\u0022", + "name": "delunch", + "description": "updated", + "dataSourceName": "delunch-ds", + "skillsetName": null, + "targetIndexName": "delunch-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027delunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Content-Length": "0", + "If-Match": "\u00220x8D9E1E72A496E02\u0022", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "46abf993-7fc3-11ec-b5d8-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 412, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "160", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:48:41 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "46abf993-7fc3-11ec-b5d8-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "The precondition given in one of the request headers evaluated to false. No change was made to the resource from this request." + } + } + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_basic_live.pyTestSearchClienttest_get_document.json b/sdk/search/azure-search-documents/tests/recordings/test_search_client_basic_live.pyTestSearchClienttest_get_document.json new file mode 100644 index 000000000000..4e4bf6fc177c --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/test_search_client_basic_live.pyTestSearchClienttest_get_document.json @@ -0,0 +1,607 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "df7957c6-7fc2-11ec-8187-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1000", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:45:48 GMT", + "elapsed-time": "11", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "df7957c6-7fc2-11ec-8187-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 5, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00272\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "df8f786a-7fc2-11ec-8e6f-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "469", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:45:48 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "df8f786a-7fc2-11ec-8e6f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "2", + "hotelName": "Roach Motel", + "description": "Cheapest hotel in town. Infact, a motel.", + "descriptionFr": "H\u00C3\u00B4tel le moins cher en ville. Infact, un motel.", + "category": "Budget", + "tags": [ + "motel", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": true, + "lastRenovationDate": "1982-04-28T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 49.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00273\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "dfa2016f-7fc2-11ec-a271-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "438", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:45:48 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "dfa2016f-7fc2-11ec-a271-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "3", + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "descriptionFr": "H\u00C3\u00B4tel le plus populaire en ville", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 46.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00274\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "dfb5a50d-7fc2-11ec-a5cb-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "416", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:45:48 GMT", + "elapsed-time": "5", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "dfb5a50d-7fc2-11ec-a5cb-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "4", + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "descriptionFr": "Assez bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00275\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "dfc8bf68-7fc2-11ec-8e7c-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "418", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:45:48 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "dfc8bf68-7fc2-11ec-8e7c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "5", + "hotelName": "Comfy Place", + "description": "Another good hotel", + "descriptionFr": "Un autre bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "2012-08-12T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00276\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "dfdc35c1-7fc2-11ec-9a61-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "279", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:45:49 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "dfdc35c1-7fc2-11ec-9a61-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "6", + "hotelName": null, + "description": "Surprisingly expensive. Model suites have an ocean-view.", + "descriptionFr": null, + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": null, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00277\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "dfefbc0d-7fc2-11ec-8c9e-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "402", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:45:49 GMT", + "elapsed-time": "5", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "dfefbc0d-7fc2-11ec-8c9e-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "7", + "hotelName": "Modern Stay", + "description": "Modern architecture, very polite staff and very clean. Also very affordable.", + "descriptionFr": "Architecture moderne, personnel poli et tr\u00C3\u00A8s propre. Aussi tr\u00C3\u00A8s abordable.", + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": null, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00278\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e002eaa3-7fc2-11ec-a89d-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "483", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:45:49 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e002eaa3-7fc2-11ec-a89d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "8", + "hotelName": null, + "description": "Has some road noise and is next to the very police station. Bathrooms had morel coverings.", + "descriptionFr": "Il y a du bruit de la route et se trouve \u00C3\u00A0 c\u00C3\u00B4t\u00C3\u00A9 de la station de police. Les salles de bain avaient des rev\u00C3\u00AAtements de morilles.", + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": null, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00279\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e01681b8-7fc2-11ec-b09e-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1742", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:45:49 GMT", + "elapsed-time": "10", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e01681b8-7fc2-11ec-b09e-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "9", + "hotelName": "Secret Point Motel", + "description": "The hotel is ideally located on the main commercial artery of the city in the heart of New York. A few minutes away is Time\u0027s Square and the historic centre of the city, as well as other places of interest that make New York one of America\u0027s most attractive and cosmopolitan cities.", + "descriptionFr": "L\u0027h\u00C3\u00B4tel est id\u00C3\u00A9alement situ\u00C3\u00A9 sur la principale art\u00C3\u00A8re commerciale de la ville en plein c\u00C5\u201Cur de New York. A quelques minutes se trouve la place du temps et le centre historique de la ville, ainsi que d\u0027autres lieux d\u0027int\u00C3\u00A9r\u00C3\u00AAt qui font de New York l\u0027une des villes les plus attractives et cosmopolites de l\u0027Am\u00C3\u00A9rique.", + "category": "Boutique", + "tags": [ + "pool", + "air conditioning", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1970-01-18T05:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -73.975403, + 40.760586 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "677 5th Ave", + "city": "New York", + "stateProvince": "NY", + "country": "USA", + "postalCode": "10022" + }, + "rooms": [ + { + "description": "Budget Room, 1 Queen Bed (Cityside)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (c\u00C3\u00B4t\u00C3\u00A9 ville)", + "type": "Budget Room", + "baseRate": 9.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd" + ] + }, + { + "description": "Budget Room, 1 King Bed (Mountain View)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 tr\u00C3\u00A8s grand lit (Mountain View)", + "type": "Budget Room", + "baseRate": 8.09, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd", + "jacuzzi tub" + ] + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u002710\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e02b6f02-7fc2-11ec-bb86-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1466", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:45:49 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e02b6f02-7fc2-11ec-bb86-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "10", + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "descriptionFr": "\u00C3\u2030conomisez jusqu\u0027\u00C3\u00A0 50% sur les h\u00C3\u00B4tels traditionnels. WiFi gratuit, tr\u00C3\u00A8s bien situ\u00C3\u00A9 pr\u00C3\u00A8s du centre-ville, cuisine compl\u00C3\u00A8te, laveuse \u0026 s\u00C3\u00A9cheuse, support 24/7, bowling, centre de fitness et plus encore.", + "category": "Budget", + "tags": [ + "24-hour front desk service", + "coffee in lobby", + "restaurant" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1999-09-06T00:00:00Z", + "rating": 3, + "location": { + "type": "Point", + "coordinates": [ + -78.940483, + 35.90416 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "6910 Fayetteville Rd", + "city": "Durham", + "stateProvince": "NC", + "country": "USA", + "postalCode": "27713" + }, + "rooms": [ + { + "description": "Suite, 1 King Bed (Amenities)", + "descriptionFr": "Suite, 1 tr\u00C3\u00A8s grand lit (Services)", + "type": "Suite", + "baseRate": 2.44, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "coffee maker" + ] + }, + { + "description": "Budget Room, 1 Queen Bed (Amenities)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (Services)", + "type": "Budget Room", + "baseRate": 7.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": false, + "tags": [ + "coffee maker" + ] + } + ] + } + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_basic_live.pyTestSearchClienttest_get_document_count.json b/sdk/search/azure-search-documents/tests/recordings/test_search_client_basic_live.pyTestSearchClienttest_get_document_count.json new file mode 100644 index 000000000000..c35233619eac --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/test_search_client_basic_live.pyTestSearchClienttest_get_document_count.json @@ -0,0 +1,34 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "daffe1dc-7fc2-11ec-a6a5-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:45:41 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "daffe1dc-7fc2-11ec-a6a5-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF10" + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_basic_live.pyTestSearchClienttest_get_document_missing.json b/sdk/search/azure-search-documents/tests/recordings/test_search_client_basic_live.pyTestSearchClienttest_get_document_missing.json new file mode 100644 index 000000000000..b0653bb73ef8 --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/test_search_client_basic_live.pyTestSearchClienttest_get_document_missing.json @@ -0,0 +1,29 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271000\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e46fcd5e-7fc2-11ec-8970-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:45:56 GMT", + "elapsed-time": "5", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "e46fcd5e-7fc2-11ec-8970-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_basic_live.test_get_document.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_basic_live.test_get_document.yaml deleted file mode 100644 index 017e0f0f0036..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_basic_live.test_get_document.yaml +++ /dev/null @@ -1,494 +0,0 @@ -interactions: -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchcca2132f.search.windows.net/indexes('drgqefsg')/docs('1')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"1","hotelName":"Fancy Stay","description":"Best hotel in - town if you like luxury hotels. They have an amazing infinity pool, a spa, - and a really helpful concierge. The location is perfect -- right downtown, - close to all the tourist attractions. We highly recommend this hotel.","descriptionFr":"Meilleur - h\u00c3\u00b4tel en ville si vous aimez les h\u00c3\u00b4tels de luxe. Ils - ont une magnifique piscine \u00c3\u00a0 d\u00c3\u00a9bordement, un spa et - un concierge tr\u00c3\u00a8s utile. L''emplacement est parfait \u00e2\u20ac\u201c - en plein centre, \u00c3\u00a0 proximit\u00c3\u00a9 de toutes les attractions - touristiques. Nous recommandons fortement cet h\u00c3\u00b4tel.","category":"Luxury","tags":["pool","view","wifi","concierge"],"parkingIncluded":false,"smokingAllowed":false,"lastRenovationDate":"2010-06-27T00:00:00Z","rating":5,"location":{"type":"Point","coordinates":[-122.131577,47.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '1000' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:05:25 GMT - elapsed-time: - - '583' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - a2d410aa-0a7d-11ec-8814-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchcca2132f.search.windows.net/indexes('drgqefsg')/docs('2')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"2","hotelName":"Roach Motel","description":"Cheapest hotel - in town. Infact, a motel.","descriptionFr":"H\u00c3\u00b4tel le moins cher - en ville. Infact, un motel.","category":"Budget","tags":["motel","budget"],"parkingIncluded":true,"smokingAllowed":true,"lastRenovationDate":"1982-04-28T00:00:00Z","rating":1,"location":{"type":"Point","coordinates":[-122.131577,49.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '469' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:05:25 GMT - elapsed-time: - - '8' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - a3b15362-0a7d-11ec-bede-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchcca2132f.search.windows.net/indexes('drgqefsg')/docs('3')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"3","hotelName":"EconoStay","description":"Very popular - hotel in town","descriptionFr":"H\u00c3\u00b4tel le plus populaire en ville","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,46.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '438' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:05:25 GMT - elapsed-time: - - '6' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - a3bb5d13-0a7d-11ec-9350-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchcca2132f.search.windows.net/indexes('drgqefsg')/docs('4')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"4","hotelName":"Express Rooms","description":"Pretty good - hotel","descriptionFr":"Assez bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '416' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:05:25 GMT - elapsed-time: - - '11' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - a3c3e84e-0a7d-11ec-a75d-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchcca2132f.search.windows.net/indexes('drgqefsg')/docs('5')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"5","hotelName":"Comfy Place","description":"Another good - hotel","descriptionFr":"Un autre bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"2012-08-12T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '418' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:05:25 GMT - elapsed-time: - - '7' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - a3ce966c-0a7d-11ec-b4ea-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchcca2132f.search.windows.net/indexes('drgqefsg')/docs('6')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"6","hotelName":null,"description":"Surprisingly expensive. - Model suites have an ocean-view.","descriptionFr":null,"category":null,"tags":[],"parkingIncluded":null,"smokingAllowed":null,"lastRenovationDate":null,"rating":null,"location":null,"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '279' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:05:25 GMT - elapsed-time: - - '7' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - a3d7aa3a-0a7d-11ec-8c38-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchcca2132f.search.windows.net/indexes('drgqefsg')/docs('7')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"7","hotelName":"Modern Stay","description":"Modern architecture, - very polite staff and very clean. Also very affordable.","descriptionFr":"Architecture - moderne, personnel poli et tr\u00c3\u00a8s propre. Aussi tr\u00c3\u00a8s abordable.","category":null,"tags":[],"parkingIncluded":null,"smokingAllowed":null,"lastRenovationDate":null,"rating":null,"location":null,"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '402' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:05:25 GMT - elapsed-time: - - '6' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - a3e1bd66-0a7d-11ec-8a20-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchcca2132f.search.windows.net/indexes('drgqefsg')/docs('8')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"8","hotelName":null,"description":"Has some road noise - and is next to the very police station. Bathrooms had morel coverings.","descriptionFr":"Il - y a du bruit de la route et se trouve \u00c3\u00a0 c\u00c3\u00b4t\u00c3\u00a9 - de la station de police. Les salles de bain avaient des rev\u00c3\u00aatements - de morilles.","category":null,"tags":[],"parkingIncluded":null,"smokingAllowed":null,"lastRenovationDate":null,"rating":null,"location":null,"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '483' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:05:25 GMT - elapsed-time: - - '6' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - a3eb2e06-0a7d-11ec-ae98-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchcca2132f.search.windows.net/indexes('drgqefsg')/docs('9')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"9","hotelName":"Secret Point Motel","description":"The - hotel is ideally located on the main commercial artery of the city in the - heart of New York. A few minutes away is Time''s Square and the historic centre - of the city, as well as other places of interest that make New York one of - America''s most attractive and cosmopolitan cities.","descriptionFr":"L''h\u00c3\u00b4tel - est id\u00c3\u00a9alement situ\u00c3\u00a9 sur la principale art\u00c3\u00a8re - commerciale de la ville en plein c\u00c5\u201cur de New York. A quelques minutes - se trouve la place du temps et le centre historique de la ville, ainsi que - d''autres lieux d''int\u00c3\u00a9r\u00c3\u00aat qui font de New York l''une - des villes les plus attractives et cosmopolites de l''Am\u00c3\u00a9rique.","category":"Boutique","tags":["pool","air - conditioning","concierge"],"parkingIncluded":false,"smokingAllowed":true,"lastRenovationDate":"1970-01-18T05:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-73.975403,40.760586],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":{"streetAddress":"677 - 5th Ave","city":"New York","stateProvince":"NY","country":"USA","postalCode":"10022"},"rooms":[{"description":"Budget - Room, 1 Queen Bed (Cityside)","descriptionFr":"Chambre \u00c3\u2030conomique, - 1 grand lit (c\u00c3\u00b4t\u00c3\u00a9 ville)","type":"Budget Room","baseRate":9.69,"bedOptions":"1 - Queen Bed","sleepsCount":2,"smokingAllowed":true,"tags":["vcr/dvd"]},{"description":"Budget - Room, 1 King Bed (Mountain View)","descriptionFr":"Chambre \u00c3\u2030conomique, - 1 tr\u00c3\u00a8s grand lit (Mountain View)","type":"Budget Room","baseRate":8.09,"bedOptions":"1 - King Bed","sleepsCount":2,"smokingAllowed":true,"tags":["vcr/dvd","jacuzzi - tub"]}]}' - headers: - cache-control: - - no-cache - content-length: - - '1742' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:05:25 GMT - elapsed-time: - - '13' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - a3f9be09-0a7d-11ec-ab49-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchcca2132f.search.windows.net/indexes('drgqefsg')/docs('10')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"10","hotelName":"Countryside Hotel","description":"Save - up to 50% off traditional hotels. Free WiFi, great location near downtown, - full kitchen, washer & dryer, 24/7 support, bowling alley, fitness center - and more.","descriptionFr":"\u00c3\u2030conomisez jusqu''\u00c3\u00a0 50% - sur les h\u00c3\u00b4tels traditionnels. WiFi gratuit, tr\u00c3\u00a8s bien - situ\u00c3\u00a9 pr\u00c3\u00a8s du centre-ville, cuisine compl\u00c3\u00a8te, - laveuse & s\u00c3\u00a9cheuse, support 24/7, bowling, centre de fitness et - plus encore.","category":"Budget","tags":["24-hour front desk service","coffee - in lobby","restaurant"],"parkingIncluded":false,"smokingAllowed":true,"lastRenovationDate":"1999-09-06T00:00:00Z","rating":3,"location":{"type":"Point","coordinates":[-78.940483,35.90416],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":{"streetAddress":"6910 - Fayetteville Rd","city":"Durham","stateProvince":"NC","country":"USA","postalCode":"27713"},"rooms":[{"description":"Suite, - 1 King Bed (Amenities)","descriptionFr":"Suite, 1 tr\u00c3\u00a8s grand lit - (Services)","type":"Suite","baseRate":2.44,"bedOptions":"1 King Bed","sleepsCount":2,"smokingAllowed":true,"tags":["coffee - maker"]},{"description":"Budget Room, 1 Queen Bed (Amenities)","descriptionFr":"Chambre - \u00c3\u2030conomique, 1 grand lit (Services)","type":"Budget Room","baseRate":7.69,"bedOptions":"1 - Queen Bed","sleepsCount":2,"smokingAllowed":false,"tags":["coffee maker"]}]}' - headers: - cache-control: - - no-cache - content-length: - - '1466' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:05:25 GMT - elapsed-time: - - '9' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - a40549c0-0a7d-11ec-ba82-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_basic_live.test_get_document_count.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_basic_live.test_get_document_count.yaml deleted file mode 100644 index 6b5721bc881a..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_basic_live.test_get_document_count.yaml +++ /dev/null @@ -1,46 +0,0 @@ -interactions: -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search485f15b7.search.windows.net/indexes('drgqefsg')/docs/$count?api-version=2021-04-30-Preview - response: - body: - string: "\uFEFF10" - headers: - cache-control: - - no-cache - content-length: - - '5' - content-type: - - text/plain - date: - - Tue, 31 Aug 2021 17:05:41 GMT - elapsed-time: - - '80' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - acb9dedd-0a7d-11ec-bb85-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_basic_live.test_get_document_missing.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_basic_live.test_get_document_missing.yaml deleted file mode 100644 index a7728743727f..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_basic_live.test_get_document_missing.yaml +++ /dev/null @@ -1,38 +0,0 @@ -interactions: -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search751b1688.search.windows.net/indexes('drgqefsg')/docs('1000')?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - content-length: - - '0' - date: - - Tue, 31 Aug 2021 17:05:54 GMT - elapsed-time: - - '22' - expires: - - '-1' - pragma: - - no-cache - request-id: - - b521612f-0a7d-11ec-a57b-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 404 - message: Not Found -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.pyTestSearchIndexingBufferedSendertest_search_client_index_buffered_sender.json b/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.pyTestSearchIndexingBufferedSendertest_search_client_index_buffered_sender.json new file mode 100644 index 000000000000..d9f2132bde72 --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.pyTestSearchIndexingBufferedSendertest_search_client_index_buffered_sender.json @@ -0,0 +1,1549 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "bb845ca1-7fc2-11ec-9e34-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "6696", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:44:49 GMT", + "elapsed-time": "25", + "ETag": "W/\u00220x8D9E1E69CD880E9\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "bb845ca1-7fc2-11ec-9e34-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E69CD880E9\u0022", + "name": "drgqefsg", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "hotelName", + "type": "Edm.String", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "description", + "type": "Edm.String", + "searchable": true, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": "en.lucene", + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "descriptionFr", + "type": "Edm.String", + "searchable": true, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": "fr.lucene", + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "category", + "type": "Edm.String", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "tags", + "type": "Collection(Edm.String)", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": false, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "parkingIncluded", + "type": "Edm.Boolean", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "smokingAllowed", + "type": "Edm.Boolean", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "lastRenovationDate", + "type": "Edm.DateTimeOffset", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "rating", + "type": "Edm.Int32", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "location", + "type": "Edm.GeographyPoint", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "address", + "type": "Edm.ComplexType", + "fields": [ + { + "name": "streetAddress", + "type": "Edm.String", + "searchable": true, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "city", + "type": "Edm.String", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "stateProvince", + "type": "Edm.String", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "country", + "type": "Edm.String", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "postalCode", + "type": "Edm.String", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ] + }, + { + "name": "rooms", + "type": "Collection(Edm.ComplexType)", + "fields": [ + { + "name": "description", + "type": "Edm.String", + "searchable": true, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": "en.lucene", + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "descriptionFr", + "type": "Edm.String", + "searchable": true, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": "fr.lucene", + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "type", + "type": "Edm.String", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": false, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": false, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "bedOptions", + "type": "Edm.String", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": false, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "sleepsCount", + "type": "Edm.Int32", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": false, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "smokingAllowed", + "type": "Edm.Boolean", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": false, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "tags", + "type": "Collection(Edm.String)", + "searchable": true, + "filterable": true, + "retrievable": true, + "sortable": false, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ] + } + ], + "scoringProfiles": [ + { + "name": "nearest", + "functionAggregation": "sum", + "text": null, + "functions": [ + { + "fieldName": "location", + "interpolation": "linear", + "type": "distance", + "boost": 2.0, + "freshness": null, + "magnitude": null, + "distance": { + "referencePointParameter": "myloc", + "boostingDistance": 100.0 + }, + "tag": null + } + ] + } + ], + "corsOptions": null, + "suggesters": [ + { + "name": "sg", + "searchMode": "analyzingInfixMatching", + "sourceFields": [ + "description", + "hotelName" + ] + } + ], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "217", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "bbf3bd44-7fc2-11ec-a232-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1000", + "rating": 5, + "rooms": [], + "hotelName": "Azure Inn", + "@search.action": "upload" + }, + { + "hotelId": "1001", + "rating": 4, + "rooms": [], + "hotelName": "Redmond Hotel", + "@search.action": "upload" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "143", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:44:49 GMT", + "elapsed-time": "33", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "bbf3bd44-7fc2-11ec-a232-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1000", + "status": true, + "errorMessage": null, + "statusCode": 201 + }, + { + "key": "1001", + "status": true, + "errorMessage": null, + "statusCode": 201 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "bddec438-7fc2-11ec-97e1-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:44:52 GMT", + "elapsed-time": "9", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "bddec438-7fc2-11ec-97e1-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF12" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271000\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "bdfc4845-7fc2-11ec-a6fb-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "232", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:44:52 GMT", + "elapsed-time": "9", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "bdfc4845-7fc2-11ec-a6fb-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1000", + "hotelName": "Azure Inn", + "description": null, + "descriptionFr": null, + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": 5, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271001\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "be10f2d0-7fc2-11ec-ad0e-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "236", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:44:52 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "be10f2d0-7fc2-11ec-ad0e-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1001", + "hotelName": "Redmond Hotel", + "description": null, + "descriptionFr": null, + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": 4, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "214", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "be247537-7fc2-11ec-a3b7-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1002", + "rating": 5, + "rooms": [], + "hotelName": "Azure Inn", + "@search.action": "upload" + }, + { + "hotelId": "3", + "rating": 4, + "rooms": [], + "hotelName": "Redmond Hotel", + "@search.action": "upload" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "140", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:44:52 GMT", + "elapsed-time": "42", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "be247537-7fc2-11ec-a3b7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1002", + "status": true, + "errorMessage": null, + "statusCode": 201 + }, + { + "key": "3", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c006b447-7fc2-11ec-b73c-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:44:56 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c006b447-7fc2-11ec-b73c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF13" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "103", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c0195571-7fc2-11ec-b3b0-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "3", + "@search.action": "delete" + }, + { + "hotelId": "4", + "@search.action": "delete" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "137", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:44:56 GMT", + "elapsed-time": "31", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c0195571-7fc2-11ec-b3b0-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "3", + "status": true, + "errorMessage": null, + "statusCode": 200 + }, + { + "key": "4", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c1fa4c7e-7fc2-11ec-a664-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:44:59 GMT", + "elapsed-time": "71", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c1fa4c7e-7fc2-11ec-a664-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF11" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00273\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c2176ebe-7fc2-11ec-b382-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:44:59 GMT", + "elapsed-time": "6", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "c2176ebe-7fc2-11ec-b382-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00274\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c22a3cc0-7fc2-11ec-861a-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:44:59 GMT", + "elapsed-time": "6", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "c22a3cc0-7fc2-11ec-861a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "106", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c23bede7-7fc2-11ec-9dde-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1003", + "@search.action": "delete" + }, + { + "hotelId": "2", + "@search.action": "delete" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "140", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:44:59 GMT", + "elapsed-time": "38", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c23bede7-7fc2-11ec-9dde-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1003", + "status": true, + "errorMessage": null, + "statusCode": 200 + }, + { + "key": "2", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c41e8a8a-7fc2-11ec-841e-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:45:02 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c41e8a8a-7fc2-11ec-841e-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF10" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271003\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c431b110-7fc2-11ec-951b-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:45:03 GMT", + "elapsed-time": "5", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "c431b110-7fc2-11ec-951b-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00272\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c444d11f-7fc2-11ec-985d-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:45:03 GMT", + "elapsed-time": "5", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "c444d11f-7fc2-11ec-985d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "127", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c457efdc-7fc2-11ec-89ed-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "5", + "rating": 1, + "@search.action": "merge" + }, + { + "hotelId": "6", + "rating": 2, + "@search.action": "merge" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "137", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:45:03 GMT", + "elapsed-time": "42", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c457efdc-7fc2-11ec-89ed-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "5", + "status": true, + "errorMessage": null, + "statusCode": 200 + }, + { + "key": "6", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c63baf11-7fc2-11ec-86a4-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:45:06 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c63baf11-7fc2-11ec-86a4-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF10" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00275\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c64f3c24-7fc2-11ec-95c6-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "418", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:45:06 GMT", + "elapsed-time": "8", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c64f3c24-7fc2-11ec-95c6-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "5", + "hotelName": "Comfy Place", + "description": "Another good hotel", + "descriptionFr": "Un autre bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "2012-08-12T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00276\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c662b2fd-7fc2-11ec-a3db-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "276", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:45:06 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c662b2fd-7fc2-11ec-a3db-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "6", + "hotelName": null, + "description": "Surprisingly expensive. Model suites have an ocean-view.", + "descriptionFr": null, + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": 2, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "130", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c675daab-7fc2-11ec-aa91-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1003", + "rating": 1, + "@search.action": "merge" + }, + { + "hotelId": "1", + "rating": 2, + "@search.action": "merge" + } + ] + }, + "StatusCode": 207, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "158", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:45:06 GMT", + "elapsed-time": "34", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c675daab-7fc2-11ec-aa91-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1003", + "status": false, + "errorMessage": "Document not found.", + "statusCode": 404 + }, + { + "key": "1", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c85bef26-7fc2-11ec-aac6-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:45:09 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c85bef26-7fc2-11ec-aac6-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF10" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271003\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c86e084e-7fc2-11ec-80bb-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:45:09 GMT", + "elapsed-time": "5", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "c86e084e-7fc2-11ec-80bb-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c880495b-7fc2-11ec-9155-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1000", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:45:09 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c880495b-7fc2-11ec-9155-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 2, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "146", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "c893c455-7fc2-11ec-9e4d-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1003", + "rating": 1, + "@search.action": "mergeOrUpload" + }, + { + "hotelId": "1", + "rating": 2, + "@search.action": "mergeOrUpload" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "140", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:45:10 GMT", + "elapsed-time": "24", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "c893c455-7fc2-11ec-9e4d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1003", + "status": true, + "errorMessage": null, + "statusCode": 201 + }, + { + "key": "1", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ca754b07-7fc2-11ec-9047-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:45:13 GMT", + "elapsed-time": "20", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ca754b07-7fc2-11ec-9047-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF11" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271003\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ca8ac69a-7fc2-11ec-b682-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "225", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:45:13 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ca8ac69a-7fc2-11ec-b682-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1003", + "hotelName": null, + "description": null, + "descriptionFr": null, + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": 1, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ca9db955-7fc2-11ec-bbee-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1000", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:45:13 GMT", + "elapsed-time": "5", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ca9db955-7fc2-11ec-bbee-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 2, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_delete_documents_existing.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_delete_documents_existing.yaml deleted file mode 100644 index e8ee422fc836..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_delete_documents_existing.yaml +++ /dev/null @@ -1,213 +0,0 @@ -interactions: -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchf9201cc0.search.windows.net/indexes('drgqefsg')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchf9201cc0.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CA19E42FEA6\"","name":"drgqefsg","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"hotelName","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"description","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"en.lucene","normalizer":null,"synonymMaps":[]},{"name":"descriptionFr","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"fr.lucene","normalizer":null,"synonymMaps":[]},{"name":"category","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"tags","type":"Collection(Edm.String)","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"parkingIncluded","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"smokingAllowed","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"lastRenovationDate","type":"Edm.DateTimeOffset","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"rating","type":"Edm.Int32","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"location","type":"Edm.GeographyPoint","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"address","type":"Edm.ComplexType","fields":[{"name":"streetAddress","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"city","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"stateProvince","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"country","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"postalCode","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}]},{"name":"rooms","type":"Collection(Edm.ComplexType)","fields":[{"name":"description","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"en.lucene","normalizer":null,"synonymMaps":[]},{"name":"descriptionFr","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"fr.lucene","normalizer":null,"synonymMaps":[]},{"name":"type","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"baseRate","type":"Edm.Double","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"bedOptions","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"sleepsCount","type":"Edm.Int32","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"smokingAllowed","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"tags","type":"Collection(Edm.String)","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}]}],"scoringProfiles":[{"name":"nearest","functionAggregation":"sum","text":null,"functions":[{"fieldName":"location","interpolation":"linear","type":"distance","boost":2.0,"freshness":null,"magnitude":null,"distance":{"referencePointParameter":"myloc","boostingDistance":100.0},"tag":null}]}],"corsOptions":null,"suggesters":[{"name":"sg","searchMode":"analyzingInfixMatching","sourceFields":["description","hotelName"]}],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '6676' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:06:09 GMT - elapsed-time: - - '668' - etag: - - W/"0x8D96CA19E42FEA6" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - bd4b77a0-0a7d-11ec-8961-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"value": [{"hotelId": "3", "@search.action": "delete"}, {"hotelId": "4", - "@search.action": "delete"}]}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '103' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchf9201cc0.search.windows.net/indexes('drgqefsg')/docs/search.index?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"key":"3","status":true,"errorMessage":null,"statusCode":200},{"key":"4","status":true,"errorMessage":null,"statusCode":200}]}' - headers: - cache-control: - - no-cache - content-length: - - '137' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:06:09 GMT - elapsed-time: - - '843' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - bdde8a95-0a7d-11ec-941b-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchf9201cc0.search.windows.net/indexes('drgqefsg')/docs/$count?api-version=2021-04-30-Preview - response: - body: - string: "\uFEFF8" - headers: - cache-control: - - no-cache - content-length: - - '4' - content-type: - - text/plain - date: - - Tue, 31 Aug 2021 17:06:14 GMT - elapsed-time: - - '63' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - c0508d3a-0a7d-11ec-8d41-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchf9201cc0.search.windows.net/indexes('drgqefsg')/docs('3')?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - content-length: - - '0' - date: - - Tue, 31 Aug 2021 17:06:14 GMT - elapsed-time: - - '4' - expires: - - '-1' - pragma: - - no-cache - request-id: - - c08d0121-0a7d-11ec-b1bd-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 404 - message: Not Found -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchf9201cc0.search.windows.net/indexes('drgqefsg')/docs('4')?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - content-length: - - '0' - date: - - Tue, 31 Aug 2021 17:06:14 GMT - elapsed-time: - - '3' - expires: - - '-1' - pragma: - - no-cache - request-id: - - c0948d81-0a7d-11ec-9903-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 404 - message: Not Found -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_delete_documents_missing.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_delete_documents_missing.yaml deleted file mode 100644 index 2fd1af9830b9..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_delete_documents_missing.yaml +++ /dev/null @@ -1,213 +0,0 @@ -interactions: -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchdc521c4f.search.windows.net/indexes('drgqefsg')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchdc521c4f.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CA1AAE65460\"","name":"drgqefsg","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"hotelName","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"description","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"en.lucene","normalizer":null,"synonymMaps":[]},{"name":"descriptionFr","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"fr.lucene","normalizer":null,"synonymMaps":[]},{"name":"category","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"tags","type":"Collection(Edm.String)","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"parkingIncluded","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"smokingAllowed","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"lastRenovationDate","type":"Edm.DateTimeOffset","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"rating","type":"Edm.Int32","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"location","type":"Edm.GeographyPoint","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"address","type":"Edm.ComplexType","fields":[{"name":"streetAddress","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"city","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"stateProvince","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"country","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"postalCode","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}]},{"name":"rooms","type":"Collection(Edm.ComplexType)","fields":[{"name":"description","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"en.lucene","normalizer":null,"synonymMaps":[]},{"name":"descriptionFr","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"fr.lucene","normalizer":null,"synonymMaps":[]},{"name":"type","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"baseRate","type":"Edm.Double","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"bedOptions","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"sleepsCount","type":"Edm.Int32","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"smokingAllowed","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"tags","type":"Collection(Edm.String)","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}]}],"scoringProfiles":[{"name":"nearest","functionAggregation":"sum","text":null,"functions":[{"fieldName":"location","interpolation":"linear","type":"distance","boost":2.0,"freshness":null,"magnitude":null,"distance":{"referencePointParameter":"myloc","boostingDistance":100.0},"tag":null}]}],"corsOptions":null,"suggesters":[{"name":"sg","searchMode":"analyzingInfixMatching","sourceFields":["description","hotelName"]}],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '6676' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:06:30 GMT - elapsed-time: - - '60' - etag: - - W/"0x8D96CA1AAE65460" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - c9f7c33d-0a7d-11ec-8df1-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"value": [{"hotelId": "1000", "@search.action": "delete"}, {"hotelId": - "4", "@search.action": "delete"}]}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '106' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchdc521c4f.search.windows.net/indexes('drgqefsg')/docs/search.index?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"key":"1000","status":true,"errorMessage":null,"statusCode":200},{"key":"4","status":true,"errorMessage":null,"statusCode":200}]}' - headers: - cache-control: - - no-cache - content-length: - - '140' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:06:29 GMT - elapsed-time: - - '223' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - ca2b3f4f-0a7d-11ec-8764-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchdc521c4f.search.windows.net/indexes('drgqefsg')/docs/$count?api-version=2021-04-30-Preview - response: - body: - string: "\uFEFF9" - headers: - cache-control: - - no-cache - content-length: - - '4' - content-type: - - text/plain - date: - - Tue, 31 Aug 2021 17:06:33 GMT - elapsed-time: - - '5' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - cc39f6ce-0a7d-11ec-ad39-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchdc521c4f.search.windows.net/indexes('drgqefsg')/docs('1000')?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - content-length: - - '0' - date: - - Tue, 31 Aug 2021 17:06:33 GMT - elapsed-time: - - '5' - expires: - - '-1' - pragma: - - no-cache - request-id: - - cc69007d-0a7d-11ec-a6d5-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 404 - message: Not Found -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchdc521c4f.search.windows.net/indexes('drgqefsg')/docs('4')?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - content-length: - - '0' - date: - - Tue, 31 Aug 2021 17:06:33 GMT - elapsed-time: - - '3' - expires: - - '-1' - pragma: - - no-cache - request-id: - - cc72154c-0a7d-11ec-9ac5-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 404 - message: Not Found -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_merge_documents_existing.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_merge_documents_existing.yaml deleted file mode 100644 index 75d109f28c49..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_merge_documents_existing.yaml +++ /dev/null @@ -1,231 +0,0 @@ -interactions: -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchdd361c5d.search.windows.net/indexes('drgqefsg')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchdd361c5d.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CA1B597DF8D\"","name":"drgqefsg","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"hotelName","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"description","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"en.lucene","normalizer":null,"synonymMaps":[]},{"name":"descriptionFr","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"fr.lucene","normalizer":null,"synonymMaps":[]},{"name":"category","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"tags","type":"Collection(Edm.String)","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"parkingIncluded","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"smokingAllowed","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"lastRenovationDate","type":"Edm.DateTimeOffset","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"rating","type":"Edm.Int32","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"location","type":"Edm.GeographyPoint","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"address","type":"Edm.ComplexType","fields":[{"name":"streetAddress","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"city","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"stateProvince","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"country","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"postalCode","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}]},{"name":"rooms","type":"Collection(Edm.ComplexType)","fields":[{"name":"description","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"en.lucene","normalizer":null,"synonymMaps":[]},{"name":"descriptionFr","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"fr.lucene","normalizer":null,"synonymMaps":[]},{"name":"type","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"baseRate","type":"Edm.Double","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"bedOptions","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"sleepsCount","type":"Edm.Int32","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"smokingAllowed","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"tags","type":"Collection(Edm.String)","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}]}],"scoringProfiles":[{"name":"nearest","functionAggregation":"sum","text":null,"functions":[{"fieldName":"location","interpolation":"linear","type":"distance","boost":2.0,"freshness":null,"magnitude":null,"distance":{"referencePointParameter":"myloc","boostingDistance":100.0},"tag":null}]}],"corsOptions":null,"suggesters":[{"name":"sg","searchMode":"analyzingInfixMatching","sourceFields":["description","hotelName"]}],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '6676' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:07:09 GMT - elapsed-time: - - '47' - etag: - - W/"0x8D96CA1B597DF8D" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - e16da41e-0a7d-11ec-9b2e-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"value": [{"hotelId": "3", "rating": 1, "@search.action": "merge"}, {"hotelId": - "4", "rating": 2, "@search.action": "merge"}]}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '127' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchdd361c5d.search.windows.net/indexes('drgqefsg')/docs/search.index?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"key":"3","status":true,"errorMessage":null,"statusCode":200},{"key":"4","status":true,"errorMessage":null,"statusCode":200}]}' - headers: - cache-control: - - no-cache - content-length: - - '137' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:07:09 GMT - elapsed-time: - - '44' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - e1a1aaba-0a7d-11ec-9028-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchdd361c5d.search.windows.net/indexes('drgqefsg')/docs/$count?api-version=2021-04-30-Preview - response: - body: - string: "\uFEFF10" - headers: - cache-control: - - no-cache - content-length: - - '5' - content-type: - - text/plain - date: - - Tue, 31 Aug 2021 17:07:12 GMT - elapsed-time: - - '190' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - e3936ac2-0a7d-11ec-8353-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchdd361c5d.search.windows.net/indexes('drgqefsg')/docs('3')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"3","hotelName":"EconoStay","description":"Very popular - hotel in town","descriptionFr":"H\u00c3\u00b4tel le plus populaire en ville","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":1,"location":{"type":"Point","coordinates":[-122.131577,46.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '438' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:07:13 GMT - elapsed-time: - - '33' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - e3d128ca-0a7d-11ec-9c2a-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchdd361c5d.search.windows.net/indexes('drgqefsg')/docs('4')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"4","hotelName":"Express Rooms","description":"Pretty good - hotel","descriptionFr":"Assez bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":2,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '416' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:07:13 GMT - elapsed-time: - - '5' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - e3df1e0a-0a7d-11ec-8acc-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_merge_documents_missing.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_merge_documents_missing.yaml deleted file mode 100644 index 6743d21ea6f0..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_merge_documents_missing.yaml +++ /dev/null @@ -1,223 +0,0 @@ -interactions: -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchc0cb1bec.search.windows.net/indexes('drgqefsg')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchc0cb1bec.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CA1CD200EE7\"","name":"drgqefsg","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"hotelName","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"description","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"en.lucene","normalizer":null,"synonymMaps":[]},{"name":"descriptionFr","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"fr.lucene","normalizer":null,"synonymMaps":[]},{"name":"category","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"tags","type":"Collection(Edm.String)","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"parkingIncluded","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"smokingAllowed","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"lastRenovationDate","type":"Edm.DateTimeOffset","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"rating","type":"Edm.Int32","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"location","type":"Edm.GeographyPoint","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"address","type":"Edm.ComplexType","fields":[{"name":"streetAddress","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"city","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"stateProvince","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"country","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"postalCode","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}]},{"name":"rooms","type":"Collection(Edm.ComplexType)","fields":[{"name":"description","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"en.lucene","normalizer":null,"synonymMaps":[]},{"name":"descriptionFr","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"fr.lucene","normalizer":null,"synonymMaps":[]},{"name":"type","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"baseRate","type":"Edm.Double","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"bedOptions","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"sleepsCount","type":"Edm.Int32","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"smokingAllowed","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"tags","type":"Collection(Edm.String)","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}]}],"scoringProfiles":[{"name":"nearest","functionAggregation":"sum","text":null,"functions":[{"fieldName":"location","interpolation":"linear","type":"distance","boost":2.0,"freshness":null,"magnitude":null,"distance":{"referencePointParameter":"myloc","boostingDistance":100.0},"tag":null}]}],"corsOptions":null,"suggesters":[{"name":"sg","searchMode":"analyzingInfixMatching","sourceFields":["description","hotelName"]}],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '6676' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:07:27 GMT - elapsed-time: - - '48' - etag: - - W/"0x8D96CA1CD200EE7" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - ec5a7d61-0a7d-11ec-93c0-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"value": [{"hotelId": "1000", "rating": 1, "@search.action": "merge"}, - {"hotelId": "4", "rating": 2, "@search.action": "merge"}]}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '130' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchc0cb1bec.search.windows.net/indexes('drgqefsg')/docs/search.index?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"key":"1000","status":false,"errorMessage":"Document not - found.","statusCode":404},{"key":"4","status":true,"errorMessage":null,"statusCode":200}]}' - headers: - cache-control: - - no-cache - content-length: - - '158' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:07:28 GMT - elapsed-time: - - '228' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - ec92ba91-0a7d-11ec-a3b7-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 207 - message: Multi-Status -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchc0cb1bec.search.windows.net/indexes('drgqefsg')/docs/$count?api-version=2021-04-30-Preview - response: - body: - string: "\uFEFF10" - headers: - cache-control: - - no-cache - content-length: - - '5' - content-type: - - text/plain - date: - - Tue, 31 Aug 2021 17:07:31 GMT - elapsed-time: - - '59' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - eea142a3-0a7d-11ec-9d27-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchc0cb1bec.search.windows.net/indexes('drgqefsg')/docs('1000')?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - content-length: - - '0' - date: - - Tue, 31 Aug 2021 17:07:31 GMT - elapsed-time: - - '8' - expires: - - '-1' - pragma: - - no-cache - request-id: - - eec9dfe9-0a7d-11ec-8dc9-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 404 - message: Not Found -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchc0cb1bec.search.windows.net/indexes('drgqefsg')/docs('4')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"4","hotelName":"Express Rooms","description":"Pretty good - hotel","descriptionFr":"Assez bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":2,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '416' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:07:31 GMT - elapsed-time: - - '15' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - eed2cc66-0a7d-11ec-ba18-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_merge_or_upload_documents.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_merge_or_upload_documents.yaml deleted file mode 100644 index 48b2c6361608..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_merge_or_upload_documents.yaml +++ /dev/null @@ -1,230 +0,0 @@ -interactions: -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchf9541cb7.search.windows.net/indexes('drgqefsg')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchf9541cb7.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CA1D89F21CD\"","name":"drgqefsg","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"hotelName","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"description","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"en.lucene","normalizer":null,"synonymMaps":[]},{"name":"descriptionFr","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"fr.lucene","normalizer":null,"synonymMaps":[]},{"name":"category","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"tags","type":"Collection(Edm.String)","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"parkingIncluded","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"smokingAllowed","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"lastRenovationDate","type":"Edm.DateTimeOffset","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"rating","type":"Edm.Int32","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"location","type":"Edm.GeographyPoint","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"address","type":"Edm.ComplexType","fields":[{"name":"streetAddress","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"city","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"stateProvince","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"country","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"postalCode","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}]},{"name":"rooms","type":"Collection(Edm.ComplexType)","fields":[{"name":"description","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"en.lucene","normalizer":null,"synonymMaps":[]},{"name":"descriptionFr","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"fr.lucene","normalizer":null,"synonymMaps":[]},{"name":"type","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"baseRate","type":"Edm.Double","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"bedOptions","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"sleepsCount","type":"Edm.Int32","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"smokingAllowed","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"tags","type":"Collection(Edm.String)","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}]}],"scoringProfiles":[{"name":"nearest","functionAggregation":"sum","text":null,"functions":[{"fieldName":"location","interpolation":"linear","type":"distance","boost":2.0,"freshness":null,"magnitude":null,"distance":{"referencePointParameter":"myloc","boostingDistance":100.0},"tag":null}]}],"corsOptions":null,"suggesters":[{"name":"sg","searchMode":"analyzingInfixMatching","sourceFields":["description","hotelName"]}],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '6676' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:07:46 GMT - elapsed-time: - - '30' - etag: - - W/"0x8D96CA1D89F21CD" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - f7b3a2b3-0a7d-11ec-9bd5-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"value": [{"hotelId": "1000", "rating": 1, "@search.action": "mergeOrUpload"}, - {"hotelId": "4", "rating": 2, "@search.action": "mergeOrUpload"}]}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '146' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchf9541cb7.search.windows.net/indexes('drgqefsg')/docs/search.index?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"key":"1000","status":true,"errorMessage":null,"statusCode":201},{"key":"4","status":true,"errorMessage":null,"statusCode":200}]}' - headers: - cache-control: - - no-cache - content-length: - - '140' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:07:47 GMT - elapsed-time: - - '118' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - f7e48d5d-0a7d-11ec-bc83-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchf9541cb7.search.windows.net/indexes('drgqefsg')/docs/$count?api-version=2021-04-30-Preview - response: - body: - string: "\uFEFF11" - headers: - cache-control: - - no-cache - content-length: - - '5' - content-type: - - text/plain - date: - - Tue, 31 Aug 2021 17:07:50 GMT - elapsed-time: - - '6' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - f9e44e75-0a7d-11ec-9ee3-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchf9541cb7.search.windows.net/indexes('drgqefsg')/docs('1000')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"1000","hotelName":null,"description":null,"descriptionFr":null,"category":null,"tags":[],"parkingIncluded":null,"smokingAllowed":null,"lastRenovationDate":null,"rating":1,"location":null,"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '225' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:07:50 GMT - elapsed-time: - - '6' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - fa06591a-0a7d-11ec-a7ea-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchf9541cb7.search.windows.net/indexes('drgqefsg')/docs('4')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"4","hotelName":"Express Rooms","description":"Pretty good - hotel","descriptionFr":"Assez bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":2,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '416' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:07:50 GMT - elapsed-time: - - '5' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - fa0f3c92-0a7d-11ec-b6e4-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_upload_documents_existing.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_upload_documents_existing.yaml deleted file mode 100644 index 1bedd60752a6..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_upload_documents_existing.yaml +++ /dev/null @@ -1,142 +0,0 @@ -interactions: -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchfb0a1cd2.search.windows.net/indexes('drgqefsg')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchfb0a1cd2.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CA1E30E40A0\"","name":"drgqefsg","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"hotelName","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"description","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"en.lucene","normalizer":null,"synonymMaps":[]},{"name":"descriptionFr","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"fr.lucene","normalizer":null,"synonymMaps":[]},{"name":"category","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"tags","type":"Collection(Edm.String)","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"parkingIncluded","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"smokingAllowed","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"lastRenovationDate","type":"Edm.DateTimeOffset","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"rating","type":"Edm.Int32","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"location","type":"Edm.GeographyPoint","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"address","type":"Edm.ComplexType","fields":[{"name":"streetAddress","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"city","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"stateProvince","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"country","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"postalCode","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}]},{"name":"rooms","type":"Collection(Edm.ComplexType)","fields":[{"name":"description","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"en.lucene","normalizer":null,"synonymMaps":[]},{"name":"descriptionFr","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"fr.lucene","normalizer":null,"synonymMaps":[]},{"name":"type","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"baseRate","type":"Edm.Double","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"bedOptions","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"sleepsCount","type":"Edm.Int32","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"smokingAllowed","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"tags","type":"Collection(Edm.String)","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}]}],"scoringProfiles":[{"name":"nearest","functionAggregation":"sum","text":null,"functions":[{"fieldName":"location","interpolation":"linear","type":"distance","boost":2.0,"freshness":null,"magnitude":null,"distance":{"referencePointParameter":"myloc","boostingDistance":100.0},"tag":null}]}],"corsOptions":null,"suggesters":[{"name":"sg","searchMode":"analyzingInfixMatching","sourceFields":["description","hotelName"]}],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '6676' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:08:04 GMT - elapsed-time: - - '31' - etag: - - W/"0x8D96CA1E30E40A0" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 0241f8b6-0a7e-11ec-b9fb-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"value": [{"hotelId": "1000", "rating": 5, "rooms": [], "hotelName": "Azure - Inn", "@search.action": "upload"}, {"hotelId": "3", "rating": 4, "rooms": [], - "hotelName": "Redmond Hotel", "@search.action": "upload"}]}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '214' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchfb0a1cd2.search.windows.net/indexes('drgqefsg')/docs/search.index?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"key":"1000","status":true,"errorMessage":null,"statusCode":201},{"key":"3","status":true,"errorMessage":null,"statusCode":200}]}' - headers: - cache-control: - - no-cache - content-length: - - '140' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:08:04 GMT - elapsed-time: - - '31' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 026b0816-0a7e-11ec-bae3-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchfb0a1cd2.search.windows.net/indexes('drgqefsg')/docs/$count?api-version=2021-04-30-Preview - response: - body: - string: "\uFEFF11" - headers: - cache-control: - - no-cache - content-length: - - '5' - content-type: - - text/plain - date: - - Tue, 31 Aug 2021 17:08:07 GMT - elapsed-time: - - '183' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 0463052c-0a7e-11ec-8b0d-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_upload_documents_new.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_upload_documents_new.yaml deleted file mode 100644 index a6641b0cec43..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_buffered_sender_live.test_upload_documents_new.yaml +++ /dev/null @@ -1,230 +0,0 @@ -interactions: -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search6f1f1ab1.search.windows.net/indexes('drgqefsg')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search6f1f1ab1.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CA1ED76A7BB\"","name":"drgqefsg","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"hotelName","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"description","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"en.lucene","normalizer":null,"synonymMaps":[]},{"name":"descriptionFr","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"fr.lucene","normalizer":null,"synonymMaps":[]},{"name":"category","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"tags","type":"Collection(Edm.String)","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"parkingIncluded","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"smokingAllowed","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"lastRenovationDate","type":"Edm.DateTimeOffset","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"rating","type":"Edm.Int32","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"location","type":"Edm.GeographyPoint","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"address","type":"Edm.ComplexType","fields":[{"name":"streetAddress","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"city","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"stateProvince","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"country","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"postalCode","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}]},{"name":"rooms","type":"Collection(Edm.ComplexType)","fields":[{"name":"description","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"en.lucene","normalizer":null,"synonymMaps":[]},{"name":"descriptionFr","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"fr.lucene","normalizer":null,"synonymMaps":[]},{"name":"type","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"baseRate","type":"Edm.Double","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"bedOptions","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"sleepsCount","type":"Edm.Int32","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"smokingAllowed","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"tags","type":"Collection(Edm.String)","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}]}],"scoringProfiles":[{"name":"nearest","functionAggregation":"sum","text":null,"functions":[{"fieldName":"location","interpolation":"linear","type":"distance","boost":2.0,"freshness":null,"magnitude":null,"distance":{"referencePointParameter":"myloc","boostingDistance":100.0},"tag":null}]}],"corsOptions":null,"suggesters":[{"name":"sg","searchMode":"analyzingInfixMatching","sourceFields":["description","hotelName"]}],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '6676' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:08:21 GMT - elapsed-time: - - '36' - etag: - - W/"0x8D96CA1ED76A7BB" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 0c86193e-0a7e-11ec-a4cd-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"value": [{"hotelId": "1000", "rating": 5, "rooms": [], "hotelName": "Azure - Inn", "@search.action": "upload"}, {"hotelId": "1001", "rating": 4, "rooms": - [], "hotelName": "Redmond Hotel", "@search.action": "upload"}]}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '217' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search6f1f1ab1.search.windows.net/indexes('drgqefsg')/docs/search.index?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"key":"1000","status":true,"errorMessage":null,"statusCode":201},{"key":"1001","status":true,"errorMessage":null,"statusCode":201}]}' - headers: - cache-control: - - no-cache - content-length: - - '143' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:08:22 GMT - elapsed-time: - - '40' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 0cbd3b5d-0a7e-11ec-bf1d-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search6f1f1ab1.search.windows.net/indexes('drgqefsg')/docs/$count?api-version=2021-04-30-Preview - response: - body: - string: "\uFEFF12" - headers: - cache-control: - - no-cache - content-length: - - '5' - content-type: - - text/plain - date: - - Tue, 31 Aug 2021 17:08:25 GMT - elapsed-time: - - '90' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 0eb197a9-0a7e-11ec-8f9b-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search6f1f1ab1.search.windows.net/indexes('drgqefsg')/docs('1000')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"1000","hotelName":"Azure Inn","description":null,"descriptionFr":null,"category":null,"tags":[],"parkingIncluded":null,"smokingAllowed":null,"lastRenovationDate":null,"rating":5,"location":null,"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '232' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:08:25 GMT - elapsed-time: - - '145' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 0ee029cf-0a7e-11ec-a32b-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search6f1f1ab1.search.windows.net/indexes('drgqefsg')/docs('1001')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"1001","hotelName":"Redmond Hotel","description":null,"descriptionFr":null,"category":null,"tags":[],"parkingIncluded":null,"smokingAllowed":null,"lastRenovationDate":null,"rating":4,"location":null,"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '236' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:08:25 GMT - elapsed-time: - - '7' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 0f03953f-0a7e-11ec-a2a9-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.pyTestSearchClientIndexDocumenttest_search_client_index_document.json b/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.pyTestSearchClientIndexDocumenttest_search_client_index_document.json new file mode 100644 index 000000000000..bf7d5f0d1d4c --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.pyTestSearchClientIndexDocumenttest_search_client_index_document.json @@ -0,0 +1,1095 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "217", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "9c42c175-7fc2-11ec-8c09-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1000", + "rating": 5, + "rooms": [], + "hotelName": "Azure Inn", + "@search.action": "upload" + }, + { + "hotelId": "1001", + "rating": 4, + "rooms": [], + "hotelName": "Redmond Hotel", + "@search.action": "upload" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "143", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:56 GMT", + "elapsed-time": "32", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "9c42c175-7fc2-11ec-8c09-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1000", + "status": true, + "errorMessage": null, + "statusCode": 201 + }, + { + "key": "1001", + "status": true, + "errorMessage": null, + "statusCode": 201 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "9e7bf497-7fc2-11ec-a15e-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:43:59 GMT", + "elapsed-time": "8", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "9e7bf497-7fc2-11ec-a15e-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF12" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271000\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "9e9196ac-7fc2-11ec-a5f0-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "232", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:59 GMT", + "elapsed-time": "14", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "9e9196ac-7fc2-11ec-a5f0-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1000", + "hotelName": "Azure Inn", + "description": null, + "descriptionFr": null, + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": 5, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271001\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "9ea7c56b-7fc2-11ec-974d-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "236", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:59 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "9ea7c56b-7fc2-11ec-974d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1001", + "hotelName": "Redmond Hotel", + "description": null, + "descriptionFr": null, + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": 4, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "214", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "9ebb4684-7fc2-11ec-9299-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1002", + "rating": 5, + "rooms": [], + "hotelName": "Azure Inn", + "@search.action": "upload" + }, + { + "hotelId": "3", + "rating": 4, + "rooms": [], + "hotelName": "Redmond Hotel", + "@search.action": "upload" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "140", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:59 GMT", + "elapsed-time": "37", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "9ebb4684-7fc2-11ec-9299-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1002", + "status": true, + "errorMessage": null, + "statusCode": 201 + }, + { + "key": "3", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "103", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "9ed20ff5-7fc2-11ec-8075-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "3", + "@search.action": "delete" + }, + { + "hotelId": "4", + "@search.action": "delete" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "137", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:59 GMT", + "elapsed-time": "32", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "9ed20ff5-7fc2-11ec-8075-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "3", + "status": true, + "errorMessage": null, + "statusCode": 200 + }, + { + "key": "4", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a0b52587-7fc2-11ec-a20c-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:44:03 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a0b52587-7fc2-11ec-a20c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF11" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00273\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a0c8cb26-7fc2-11ec-a83a-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:44:03 GMT", + "elapsed-time": "4", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "a0c8cb26-7fc2-11ec-a83a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00274\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a0dd995a-7fc2-11ec-bd4a-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:44:03 GMT", + "elapsed-time": "5", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "a0dd995a-7fc2-11ec-bd4a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "106", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a0f0a55c-7fc2-11ec-99e7-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1003", + "@search.action": "delete" + }, + { + "hotelId": "2", + "@search.action": "delete" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "140", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:44:03 GMT", + "elapsed-time": "26", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a0f0a55c-7fc2-11ec-99e7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1003", + "status": true, + "errorMessage": null, + "statusCode": 200 + }, + { + "key": "2", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a2d11b70-7fc2-11ec-ad29-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:44:07 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a2d11b70-7fc2-11ec-ad29-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF10" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271003\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a2e3540e-7fc2-11ec-991e-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:44:07 GMT", + "elapsed-time": "5", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "a2e3540e-7fc2-11ec-991e-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00272\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a2fa72f3-7fc2-11ec-aa95-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:44:07 GMT", + "elapsed-time": "5", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "a2fa72f3-7fc2-11ec-aa95-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "127", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a30cdf81-7fc2-11ec-8ca3-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "5", + "rating": 1, + "@search.action": "merge" + }, + { + "hotelId": "6", + "rating": 2, + "@search.action": "merge" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "137", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:44:07 GMT", + "elapsed-time": "34", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a30cdf81-7fc2-11ec-8ca3-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "5", + "status": true, + "errorMessage": null, + "statusCode": 200 + }, + { + "key": "6", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a4ed0e98-7fc2-11ec-b2b3-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:44:10 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a4ed0e98-7fc2-11ec-b2b3-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF10" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a500b973-7fc2-11ec-9136-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:44:10 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a500b973-7fc2-11ec-9136-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF10" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00275\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a5156026-7fc2-11ec-9bb6-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "418", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:44:10 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a5156026-7fc2-11ec-9bb6-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "5", + "hotelName": "Comfy Place", + "description": "Another good hotel", + "descriptionFr": "Un autre bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "2012-08-12T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00276\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a528d702-7fc2-11ec-bf36-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "276", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:44:10 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a528d702-7fc2-11ec-bf36-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "6", + "hotelName": null, + "description": "Surprisingly expensive. Model suites have an ocean-view.", + "descriptionFr": null, + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": 2, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "130", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a53bb6c5-7fc2-11ec-85ea-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1003", + "rating": 1, + "@search.action": "merge" + }, + { + "hotelId": "1", + "rating": 2, + "@search.action": "merge" + } + ] + }, + "StatusCode": 207, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "158", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:44:10 GMT", + "elapsed-time": "46", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a53bb6c5-7fc2-11ec-85ea-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1003", + "status": false, + "errorMessage": "Document not found.", + "statusCode": 404 + }, + { + "key": "1", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a72083fe-7fc2-11ec-8475-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:44:14 GMT", + "elapsed-time": "59", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a72083fe-7fc2-11ec-8475-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF10" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271003\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a73b01a1-7fc2-11ec-9318-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 404, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:44:14 GMT", + "elapsed-time": "5", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "a73b01a1-7fc2-11ec-9318-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a74c0df5-7fc2-11ec-a56e-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1000", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:44:14 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a74c0df5-7fc2-11ec-a56e-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 2, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.index?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "146", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a760bbbb-7fc2-11ec-ab95-74c63bed1137" + }, + "RequestBody": { + "value": [ + { + "hotelId": "1003", + "rating": 1, + "@search.action": "mergeOrUpload" + }, + { + "hotelId": "1", + "rating": 2, + "@search.action": "mergeOrUpload" + } + ] + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "140", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:44:14 GMT", + "elapsed-time": "23", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a760bbbb-7fc2-11ec-ab95-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "key": "1003", + "status": true, + "errorMessage": null, + "statusCode": 201 + }, + { + "key": "1", + "status": true, + "errorMessage": null, + "statusCode": 200 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/$count?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a9499e10-7fc2-11ec-a1c8-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "5", + "Content-Type": "text/plain", + "Date": "Thu, 27 Jan 2022 22:44:17 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a9499e10-7fc2-11ec-a1c8-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": "\uFEFF11" + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271003\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a95c4c2a-7fc2-11ec-a54c-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "225", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:44:18 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a95c4c2a-7fc2-11ec-a54c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1003", + "hotelName": null, + "description": null, + "descriptionFr": null, + "category": null, + "tags": [], + "parkingIncluded": null, + "smokingAllowed": null, + "lastRenovationDate": null, + "rating": 1, + "location": null, + "address": null, + "rooms": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs(\u00271\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "a96daad8-7fc2-11ec-ab84-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1000", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:44:18 GMT", + "elapsed-time": "6", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "a96daad8-7fc2-11ec-ab84-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 2, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_delete_documents_existing.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_delete_documents_existing.yaml deleted file mode 100644 index b13e16962d1c..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_delete_documents_existing.yaml +++ /dev/null @@ -1,167 +0,0 @@ -interactions: -- request: - body: '{"value": [{"hotelId": "3", "@search.action": "delete"}, {"hotelId": "4", - "@search.action": "delete"}]}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '103' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searche0dc1c73.search.windows.net/indexes('drgqefsg')/docs/search.index?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"key":"3","status":true,"errorMessage":null,"statusCode":200},{"key":"4","status":true,"errorMessage":null,"statusCode":200}]}' - headers: - cache-control: - - no-cache - content-length: - - '137' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:08:39 GMT - elapsed-time: - - '22' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 170a30d4-0a7e-11ec-b8f1-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searche0dc1c73.search.windows.net/indexes('drgqefsg')/docs/$count?api-version=2021-04-30-Preview - response: - body: - string: "\uFEFF8" - headers: - cache-control: - - no-cache - content-length: - - '4' - content-type: - - text/plain - date: - - Tue, 31 Aug 2021 17:08:42 GMT - elapsed-time: - - '5' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 19022cba-0a7e-11ec-843f-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searche0dc1c73.search.windows.net/indexes('drgqefsg')/docs('3')?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - content-length: - - '0' - date: - - Tue, 31 Aug 2021 17:08:42 GMT - elapsed-time: - - '6' - expires: - - '-1' - pragma: - - no-cache - request-id: - - 190bb212-0a7e-11ec-b46e-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 404 - message: Not Found -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searche0dc1c73.search.windows.net/indexes('drgqefsg')/docs('4')?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - content-length: - - '0' - date: - - Tue, 31 Aug 2021 17:08:42 GMT - elapsed-time: - - '6' - expires: - - '-1' - pragma: - - no-cache - request-id: - - 19153f4c-0a7e-11ec-bd6d-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 404 - message: Not Found -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_delete_documents_missing.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_delete_documents_missing.yaml deleted file mode 100644 index 65a676a08133..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_delete_documents_missing.yaml +++ /dev/null @@ -1,167 +0,0 @@ -interactions: -- request: - body: '{"value": [{"hotelId": "1000", "@search.action": "delete"}, {"hotelId": - "4", "@search.action": "delete"}]}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '106' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchc45b1c02.search.windows.net/indexes('drgqefsg')/docs/search.index?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"key":"1000","status":true,"errorMessage":null,"statusCode":200},{"key":"4","status":true,"errorMessage":null,"statusCode":200}]}' - headers: - cache-control: - - no-cache - content-length: - - '140' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:08:56 GMT - elapsed-time: - - '81' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 212cebdf-0a7e-11ec-a482-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchc45b1c02.search.windows.net/indexes('drgqefsg')/docs/$count?api-version=2021-04-30-Preview - response: - body: - string: "\uFEFF9" - headers: - cache-control: - - no-cache - content-length: - - '4' - content-type: - - text/plain - date: - - Tue, 31 Aug 2021 17:08:59 GMT - elapsed-time: - - '4' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 2322eaa1-0a7e-11ec-ac78-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchc45b1c02.search.windows.net/indexes('drgqefsg')/docs('1000')?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - content-length: - - '0' - date: - - Tue, 31 Aug 2021 17:08:59 GMT - elapsed-time: - - '3' - expires: - - '-1' - pragma: - - no-cache - request-id: - - 232becae-0a7e-11ec-a54b-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 404 - message: Not Found -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchc45b1c02.search.windows.net/indexes('drgqefsg')/docs('4')?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - content-length: - - '0' - date: - - Tue, 31 Aug 2021 17:08:59 GMT - elapsed-time: - - '4' - expires: - - '-1' - pragma: - - no-cache - request-id: - - 2333f30f-0a7e-11ec-83c5-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 404 - message: Not Found -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_merge_documents_existing.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_merge_documents_existing.yaml deleted file mode 100644 index f07bca4d549f..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_merge_documents_existing.yaml +++ /dev/null @@ -1,185 +0,0 @@ -interactions: -- request: - body: '{"value": [{"hotelId": "3", "rating": 1, "@search.action": "merge"}, {"hotelId": - "4", "rating": 2, "@search.action": "merge"}]}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '127' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchc53f1c10.search.windows.net/indexes('drgqefsg')/docs/search.index?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"key":"3","status":true,"errorMessage":null,"statusCode":200},{"key":"4","status":true,"errorMessage":null,"statusCode":200}]}' - headers: - cache-control: - - no-cache - content-length: - - '137' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:09:14 GMT - elapsed-time: - - '97' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 2c2a2ab2-0a7e-11ec-844d-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchc53f1c10.search.windows.net/indexes('drgqefsg')/docs/$count?api-version=2021-04-30-Preview - response: - body: - string: "\uFEFF10" - headers: - cache-control: - - no-cache - content-length: - - '5' - content-type: - - text/plain - date: - - Tue, 31 Aug 2021 17:09:18 GMT - elapsed-time: - - '5' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 2e307d82-0a7e-11ec-9ad4-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchc53f1c10.search.windows.net/indexes('drgqefsg')/docs('3')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"3","hotelName":"EconoStay","description":"Very popular - hotel in town","descriptionFr":"H\u00c3\u00b4tel le plus populaire en ville","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":1,"location":{"type":"Point","coordinates":[-122.131577,46.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '438' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:09:18 GMT - elapsed-time: - - '14' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 2e397bfe-0a7e-11ec-8bd9-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchc53f1c10.search.windows.net/indexes('drgqefsg')/docs('4')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"4","hotelName":"Express Rooms","description":"Pretty good - hotel","descriptionFr":"Assez bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":2,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '416' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:09:18 GMT - elapsed-time: - - '5' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 2e460721-0a7e-11ec-9933-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_merge_documents_missing.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_merge_documents_missing.yaml deleted file mode 100644 index 515fc73bdf8a..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_merge_documents_missing.yaml +++ /dev/null @@ -1,177 +0,0 @@ -interactions: -- request: - body: '{"value": [{"hotelId": "1000", "rating": 1, "@search.action": "merge"}, - {"hotelId": "4", "rating": 2, "@search.action": "merge"}]}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '130' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searcha9211b9f.search.windows.net/indexes('drgqefsg')/docs/search.index?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"key":"1000","status":false,"errorMessage":"Document not - found.","statusCode":404},{"key":"4","status":true,"errorMessage":null,"statusCode":200}]}' - headers: - cache-control: - - no-cache - content-length: - - '158' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:09:31 GMT - elapsed-time: - - '119' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 366617ae-0a7e-11ec-8286-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 207 - message: Multi-Status -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searcha9211b9f.search.windows.net/indexes('drgqefsg')/docs/$count?api-version=2021-04-30-Preview - response: - body: - string: "\uFEFF10" - headers: - cache-control: - - no-cache - content-length: - - '5' - content-type: - - text/plain - date: - - Tue, 31 Aug 2021 17:09:34 GMT - elapsed-time: - - '5' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 386863b2-0a7e-11ec-b241-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searcha9211b9f.search.windows.net/indexes('drgqefsg')/docs('1000')?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - content-length: - - '0' - date: - - Tue, 31 Aug 2021 17:09:35 GMT - elapsed-time: - - '5' - expires: - - '-1' - pragma: - - no-cache - request-id: - - 386fce0d-0a7e-11ec-be90-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 404 - message: Not Found -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searcha9211b9f.search.windows.net/indexes('drgqefsg')/docs('4')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"4","hotelName":"Express Rooms","description":"Pretty good - hotel","descriptionFr":"Assez bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":2,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '416' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:09:35 GMT - elapsed-time: - - '9' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 3876fad8-0a7e-11ec-b207-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_merge_or_upload_documents.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_merge_or_upload_documents.yaml deleted file mode 100644 index 8b7edb60f0b0..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_merge_or_upload_documents.yaml +++ /dev/null @@ -1,184 +0,0 @@ -interactions: -- request: - body: '{"value": [{"hotelId": "1000", "rating": 1, "@search.action": "mergeOrUpload"}, - {"hotelId": "4", "rating": 2, "@search.action": "mergeOrUpload"}]}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '146' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searche1101c6a.search.windows.net/indexes('drgqefsg')/docs/search.index?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"key":"1000","status":true,"errorMessage":null,"statusCode":201},{"key":"4","status":true,"errorMessage":null,"statusCode":200}]}' - headers: - cache-control: - - no-cache - content-length: - - '140' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:09:48 GMT - elapsed-time: - - '218' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 3fdef405-0a7e-11ec-9b92-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searche1101c6a.search.windows.net/indexes('drgqefsg')/docs/$count?api-version=2021-04-30-Preview - response: - body: - string: "\uFEFF11" - headers: - cache-control: - - no-cache - content-length: - - '5' - content-type: - - text/plain - date: - - Tue, 31 Aug 2021 17:09:51 GMT - elapsed-time: - - '5' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 41f035d9-0a7e-11ec-8795-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searche1101c6a.search.windows.net/indexes('drgqefsg')/docs('1000')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"1000","hotelName":null,"description":null,"descriptionFr":null,"category":null,"tags":[],"parkingIncluded":null,"smokingAllowed":null,"lastRenovationDate":null,"rating":1,"location":null,"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '225' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:09:51 GMT - elapsed-time: - - '9' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 41f755b9-0a7e-11ec-a4e7-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searche1101c6a.search.windows.net/indexes('drgqefsg')/docs('4')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"4","hotelName":"Express Rooms","description":"Pretty good - hotel","descriptionFr":"Assez bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":2,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '416' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:09:51 GMT - elapsed-time: - - '8' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 41ff215b-0a7e-11ec-87f6-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_upload_documents_existing.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_upload_documents_existing.yaml deleted file mode 100644 index eeb888f8ea42..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_upload_documents_existing.yaml +++ /dev/null @@ -1,52 +0,0 @@ -interactions: -- request: - body: '{"value": [{"hotelId": "1000", "rating": 5, "rooms": [], "hotelName": "Azure - Inn", "@search.action": "upload"}, {"hotelId": "3", "rating": 4, "rooms": [], - "hotelName": "Redmond Hotel", "@search.action": "upload"}]}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '214' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searche2c61c85.search.windows.net/indexes('drgqefsg')/docs/search.index?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"key":"1000","status":true,"errorMessage":null,"statusCode":201},{"key":"3","status":true,"errorMessage":null,"statusCode":200}]}' - headers: - cache-control: - - no-cache - content-length: - - '140' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:10:05 GMT - elapsed-time: - - '129' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 4a550357-0a7e-11ec-9d57-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_upload_documents_new.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_upload_documents_new.yaml deleted file mode 100644 index ee7ae8b4bc97..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_index_document_live.test_upload_documents_new.yaml +++ /dev/null @@ -1,184 +0,0 @@ -interactions: -- request: - body: '{"value": [{"hotelId": "1000", "rating": 5, "rooms": [], "hotelName": "Azure - Inn", "@search.action": "upload"}, {"hotelId": "1001", "rating": 4, "rooms": - [], "hotelName": "Redmond Hotel", "@search.action": "upload"}]}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '217' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search585c1a64.search.windows.net/indexes('drgqefsg')/docs/search.index?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"key":"1000","status":true,"errorMessage":null,"statusCode":201},{"key":"1001","status":true,"errorMessage":null,"statusCode":201}]}' - headers: - cache-control: - - no-cache - content-length: - - '143' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:10:19 GMT - elapsed-time: - - '121' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 52dd3f25-0a7e-11ec-b277-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search585c1a64.search.windows.net/indexes('drgqefsg')/docs/$count?api-version=2021-04-30-Preview - response: - body: - string: "\uFEFF12" - headers: - cache-control: - - no-cache - content-length: - - '5' - content-type: - - text/plain - date: - - Tue, 31 Aug 2021 17:10:22 GMT - elapsed-time: - - '5' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 54e2128f-0a7e-11ec-8a18-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search585c1a64.search.windows.net/indexes('drgqefsg')/docs('1000')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"1000","hotelName":"Azure Inn","description":null,"descriptionFr":null,"category":null,"tags":[],"parkingIncluded":null,"smokingAllowed":null,"lastRenovationDate":null,"rating":5,"location":null,"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '232' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:10:22 GMT - elapsed-time: - - '10' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 54e98e3b-0a7e-11ec-8ba1-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search585c1a64.search.windows.net/indexes('drgqefsg')/docs('1001')?api-version=2021-04-30-Preview - response: - body: - string: '{"hotelId":"1001","hotelName":"Redmond Hotel","description":null,"descriptionFr":null,"category":null,"tags":[],"parkingIncluded":null,"smokingAllowed":null,"lastRenovationDate":null,"rating":4,"location":null,"address":null,"rooms":[]}' - headers: - cache-control: - - no-cache - content-length: - - '236' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:10:22 GMT - elapsed-time: - - '7' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 54f1c06e-0a7e-11ec-b986-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.pyTestSearchClienttest_search_client.json b/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.pyTestSearchClienttest_search_client.json new file mode 100644 index 000000000000..5d25ae478def --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.pyTestSearchClienttest_search_client.json @@ -0,0 +1,2397 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "19", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "90229cd2-7fc2-11ec-beaa-74c63bed1137" + }, + "RequestBody": { + "search": "hotel" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "6156", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:36 GMT", + "elapsed-time": "50", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "90229cd2-7fc2-11ec-beaa-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.score": 0.7960079, + "hotelId": "10", + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "descriptionFr": "\u00C3\u2030conomisez jusqu\u0027\u00C3\u00A0 50% sur les h\u00C3\u00B4tels traditionnels. WiFi gratuit, tr\u00C3\u00A8s bien situ\u00C3\u00A9 pr\u00C3\u00A8s du centre-ville, cuisine compl\u00C3\u00A8te, laveuse \u0026 s\u00C3\u00A9cheuse, support 24/7, bowling, centre de fitness et plus encore.", + "category": "Budget", + "tags": [ + "24-hour front desk service", + "coffee in lobby", + "restaurant" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1999-09-06T00:00:00Z", + "rating": 3, + "location": { + "type": "Point", + "coordinates": [ + -78.940483, + 35.90416 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "6910 Fayetteville Rd", + "city": "Durham", + "stateProvince": "NC", + "country": "USA", + "postalCode": "27713" + }, + "rooms": [ + { + "description": "Suite, 1 King Bed (Amenities)", + "descriptionFr": "Suite, 1 tr\u00C3\u00A8s grand lit (Services)", + "type": "Suite", + "baseRate": 2.44, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "coffee maker" + ] + }, + { + "description": "Budget Room, 1 Queen Bed (Amenities)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (Services)", + "type": "Budget Room", + "baseRate": 7.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": false, + "tags": [ + "coffee maker" + ] + } + ] + }, + { + "@search.score": 0.27958742, + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 5, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.26639014, + "hotelId": "3", + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "descriptionFr": "H\u00C3\u00B4tel le plus populaire en ville", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 46.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "4", + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "descriptionFr": "Assez bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "5", + "hotelName": "Comfy Place", + "description": "Another good hotel", + "descriptionFr": "Un autre bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "2012-08-12T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.11774718, + "hotelId": "9", + "hotelName": "Secret Point Motel", + "description": "The hotel is ideally located on the main commercial artery of the city in the heart of New York. A few minutes away is Time\u0027s Square and the historic centre of the city, as well as other places of interest that make New York one of America\u0027s most attractive and cosmopolitan cities.", + "descriptionFr": "L\u0027h\u00C3\u00B4tel est id\u00C3\u00A9alement situ\u00C3\u00A9 sur la principale art\u00C3\u00A8re commerciale de la ville en plein c\u00C5\u201Cur de New York. A quelques minutes se trouve la place du temps et le centre historique de la ville, ainsi que d\u0027autres lieux d\u0027int\u00C3\u00A9r\u00C3\u00AAt qui font de New York l\u0027une des villes les plus attractives et cosmopolites de l\u0027Am\u00C3\u00A9rique.", + "category": "Boutique", + "tags": [ + "pool", + "air conditioning", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1970-01-18T05:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -73.975403, + 40.760586 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "677 5th Ave", + "city": "New York", + "stateProvince": "NY", + "country": "USA", + "postalCode": "10022" + }, + "rooms": [ + { + "description": "Budget Room, 1 Queen Bed (Cityside)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (c\u00C3\u00B4t\u00C3\u00A9 ville)", + "type": "Budget Room", + "baseRate": 9.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd" + ] + }, + { + "description": "Budget Room, 1 King Bed (Mountain View)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 tr\u00C3\u00A8s grand lit (Mountain View)", + "type": "Budget Room", + "baseRate": 8.09, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd", + "jacuzzi tub" + ] + } + ] + }, + { + "@search.score": 0.113759264, + "hotelId": "2", + "hotelName": "Roach Motel", + "description": "Cheapest hotel in town. Infact, a motel.", + "descriptionFr": "H\u00C3\u00B4tel le moins cher en ville. Infact, un motel.", + "category": "Budget", + "tags": [ + "motel", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": true, + "lastRenovationDate": "1982-04-28T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 49.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "19", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "909249aa-7fc2-11ec-865b-74c63bed1137" + }, + "RequestBody": { + "search": "motel" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "2277", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:36 GMT", + "elapsed-time": "13", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "909249aa-7fc2-11ec-865b-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.score": 3.4320152, + "hotelId": "2", + "hotelName": "Roach Motel", + "description": "Cheapest hotel in town. Infact, a motel.", + "descriptionFr": "H\u00C3\u00B4tel le moins cher en ville. Infact, un motel.", + "category": "Budget", + "tags": [ + "motel", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": true, + "lastRenovationDate": "1982-04-28T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 49.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.49191087, + "hotelId": "9", + "hotelName": "Secret Point Motel", + "description": "The hotel is ideally located on the main commercial artery of the city in the heart of New York. A few minutes away is Time\u0027s Square and the historic centre of the city, as well as other places of interest that make New York one of America\u0027s most attractive and cosmopolitan cities.", + "descriptionFr": "L\u0027h\u00C3\u00B4tel est id\u00C3\u00A9alement situ\u00C3\u00A9 sur la principale art\u00C3\u00A8re commerciale de la ville en plein c\u00C5\u201Cur de New York. A quelques minutes se trouve la place du temps et le centre historique de la ville, ainsi que d\u0027autres lieux d\u0027int\u00C3\u00A9r\u00C3\u00AAt qui font de New York l\u0027une des villes les plus attractives et cosmopolites de l\u0027Am\u00C3\u00A9rique.", + "category": "Boutique", + "tags": [ + "pool", + "air conditioning", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1970-01-18T05:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -73.975403, + 40.760586 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "677 5th Ave", + "city": "New York", + "stateProvince": "NY", + "country": "USA", + "postalCode": "10022" + }, + "rooms": [ + { + "description": "Budget Room, 1 Queen Bed (Cityside)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (c\u00C3\u00B4t\u00C3\u00A9 ville)", + "type": "Budget Room", + "baseRate": 9.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd" + ] + }, + { + "description": "Budget Room, 1 King Bed (Mountain View)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 tr\u00C3\u00A8s grand lit (Mountain View)", + "type": "Budget Room", + "baseRate": 8.09, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd", + "jacuzzi tub" + ] + } + ] + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "29", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "90a7bf30-7fc2-11ec-acaa-74c63bed1137" + }, + "RequestBody": { + "search": "hotel", + "top": 3 + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "2998", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:36 GMT", + "elapsed-time": "13", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "90a7bf30-7fc2-11ec-acaa-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.score": 0.7960079, + "hotelId": "10", + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "descriptionFr": "\u00C3\u2030conomisez jusqu\u0027\u00C3\u00A0 50% sur les h\u00C3\u00B4tels traditionnels. WiFi gratuit, tr\u00C3\u00A8s bien situ\u00C3\u00A9 pr\u00C3\u00A8s du centre-ville, cuisine compl\u00C3\u00A8te, laveuse \u0026 s\u00C3\u00A9cheuse, support 24/7, bowling, centre de fitness et plus encore.", + "category": "Budget", + "tags": [ + "24-hour front desk service", + "coffee in lobby", + "restaurant" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1999-09-06T00:00:00Z", + "rating": 3, + "location": { + "type": "Point", + "coordinates": [ + -78.940483, + 35.90416 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "6910 Fayetteville Rd", + "city": "Durham", + "stateProvince": "NC", + "country": "USA", + "postalCode": "27713" + }, + "rooms": [ + { + "description": "Suite, 1 King Bed (Amenities)", + "descriptionFr": "Suite, 1 tr\u00C3\u00A8s grand lit (Services)", + "type": "Suite", + "baseRate": 2.44, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "coffee maker" + ] + }, + { + "description": "Budget Room, 1 Queen Bed (Amenities)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (Services)", + "type": "Budget Room", + "baseRate": 7.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": false, + "tags": [ + "coffee maker" + ] + } + ] + }, + { + "@search.score": 0.27958742, + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 5, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.26639014, + "hotelId": "3", + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "descriptionFr": "H\u00C3\u00B4tel le plus populaire en ville", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 46.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "29", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "90bbdb1b-7fc2-11ec-b30f-74c63bed1137" + }, + "RequestBody": { + "search": "motel", + "top": 3 + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "2277", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:36 GMT", + "elapsed-time": "16", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "90bbdb1b-7fc2-11ec-b30f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.score": 3.4320152, + "hotelId": "2", + "hotelName": "Roach Motel", + "description": "Cheapest hotel in town. Infact, a motel.", + "descriptionFr": "H\u00C3\u00B4tel le moins cher en ville. Infact, un motel.", + "category": "Budget", + "tags": [ + "motel", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": true, + "lastRenovationDate": "1982-04-28T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 49.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.49191087, + "hotelId": "9", + "hotelName": "Secret Point Motel", + "description": "The hotel is ideally located on the main commercial artery of the city in the heart of New York. A few minutes away is Time\u0027s Square and the historic centre of the city, as well as other places of interest that make New York one of America\u0027s most attractive and cosmopolitan cities.", + "descriptionFr": "L\u0027h\u00C3\u00B4tel est id\u00C3\u00A9alement situ\u00C3\u00A9 sur la principale art\u00C3\u00A8re commerciale de la ville en plein c\u00C5\u201Cur de New York. A quelques minutes se trouve la place du temps et le centre historique de la ville, ainsi que d\u0027autres lieux d\u0027int\u00C3\u00A9r\u00C3\u00AAt qui font de New York l\u0027une des villes les plus attractives et cosmopolites de l\u0027Am\u00C3\u00A9rique.", + "category": "Boutique", + "tags": [ + "pool", + "air conditioning", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1970-01-18T05:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -73.975403, + 40.760586 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "677 5th Ave", + "city": "New York", + "stateProvince": "NY", + "country": "USA", + "postalCode": "10022" + }, + "rooms": [ + { + "description": "Budget Room, 1 Queen Bed (Cityside)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (c\u00C3\u00B4t\u00C3\u00A9 ville)", + "type": "Budget Room", + "baseRate": 9.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd" + ] + }, + { + "description": "Budget Room, 1 King Bed (Mountain View)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 tr\u00C3\u00A8s grand lit (Mountain View)", + "type": "Budget Room", + "baseRate": 8.09, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd", + "jacuzzi tub" + ] + } + ] + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "125", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "90d20153-7fc2-11ec-87c4-74c63bed1137" + }, + "RequestBody": { + "filter": "category eq \u0027Budget\u0027", + "orderby": "hotelName desc", + "search": "WiFi", + "select": "hotelName,category,description" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "608", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:36 GMT", + "elapsed-time": "23", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "90d20153-7fc2-11ec-87c4-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.score": 0.42169982, + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "category": "Budget" + }, + { + "@search.score": 0.7373906, + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "category": "Budget" + }, + { + "@search.score": 1.3700507, + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "category": "Budget" + }, + { + "@search.score": 0.42169982, + "hotelName": "Comfy Place", + "description": "Another good hotel", + "category": "Budget" + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "125", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "90e77b4b-7fc2-11ec-b7cf-74c63bed1137" + }, + "RequestBody": { + "filter": "category eq \u0027Budget\u0027", + "orderby": "hotelName desc", + "search": "WiFi", + "select": "hotelName,category,description" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "608", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:36 GMT", + "elapsed-time": "22", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "90e77b4b-7fc2-11ec-b7cf-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.score": 0.42169982, + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "category": "Budget" + }, + { + "@search.score": 0.7373906, + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "category": "Budget" + }, + { + "@search.score": 1.3700507, + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "category": "Budget" + }, + { + "@search.score": 0.42169982, + "hotelName": "Comfy Place", + "description": "Another good hotel", + "category": "Budget" + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "19", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "90fc3222-7fc2-11ec-9556-74c63bed1137" + }, + "RequestBody": { + "search": "hotel" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "6156", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:36 GMT", + "elapsed-time": "16", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "90fc3222-7fc2-11ec-9556-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.score": 0.7960079, + "hotelId": "10", + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "descriptionFr": "\u00C3\u2030conomisez jusqu\u0027\u00C3\u00A0 50% sur les h\u00C3\u00B4tels traditionnels. WiFi gratuit, tr\u00C3\u00A8s bien situ\u00C3\u00A9 pr\u00C3\u00A8s du centre-ville, cuisine compl\u00C3\u00A8te, laveuse \u0026 s\u00C3\u00A9cheuse, support 24/7, bowling, centre de fitness et plus encore.", + "category": "Budget", + "tags": [ + "24-hour front desk service", + "coffee in lobby", + "restaurant" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1999-09-06T00:00:00Z", + "rating": 3, + "location": { + "type": "Point", + "coordinates": [ + -78.940483, + 35.90416 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "6910 Fayetteville Rd", + "city": "Durham", + "stateProvince": "NC", + "country": "USA", + "postalCode": "27713" + }, + "rooms": [ + { + "description": "Suite, 1 King Bed (Amenities)", + "descriptionFr": "Suite, 1 tr\u00C3\u00A8s grand lit (Services)", + "type": "Suite", + "baseRate": 2.44, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "coffee maker" + ] + }, + { + "description": "Budget Room, 1 Queen Bed (Amenities)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (Services)", + "type": "Budget Room", + "baseRate": 7.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": false, + "tags": [ + "coffee maker" + ] + } + ] + }, + { + "@search.score": 0.27958742, + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 5, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.26639014, + "hotelId": "3", + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "descriptionFr": "H\u00C3\u00B4tel le plus populaire en ville", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 46.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "4", + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "descriptionFr": "Assez bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "5", + "hotelName": "Comfy Place", + "description": "Another good hotel", + "descriptionFr": "Un autre bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "2012-08-12T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.11774718, + "hotelId": "9", + "hotelName": "Secret Point Motel", + "description": "The hotel is ideally located on the main commercial artery of the city in the heart of New York. A few minutes away is Time\u0027s Square and the historic centre of the city, as well as other places of interest that make New York one of America\u0027s most attractive and cosmopolitan cities.", + "descriptionFr": "L\u0027h\u00C3\u00B4tel est id\u00C3\u00A9alement situ\u00C3\u00A9 sur la principale art\u00C3\u00A8re commerciale de la ville en plein c\u00C5\u201Cur de New York. A quelques minutes se trouve la place du temps et le centre historique de la ville, ainsi que d\u0027autres lieux d\u0027int\u00C3\u00A9r\u00C3\u00AAt qui font de New York l\u0027une des villes les plus attractives et cosmopolites de l\u0027Am\u00C3\u00A9rique.", + "category": "Boutique", + "tags": [ + "pool", + "air conditioning", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1970-01-18T05:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -73.975403, + 40.760586 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "677 5th Ave", + "city": "New York", + "stateProvince": "NY", + "country": "USA", + "postalCode": "10022" + }, + "rooms": [ + { + "description": "Budget Room, 1 Queen Bed (Cityside)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (c\u00C3\u00B4t\u00C3\u00A9 ville)", + "type": "Budget Room", + "baseRate": 9.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd" + ] + }, + { + "description": "Budget Room, 1 King Bed (Mountain View)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 tr\u00C3\u00A8s grand lit (Mountain View)", + "type": "Budget Room", + "baseRate": 8.09, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd", + "jacuzzi tub" + ] + } + ] + }, + { + "@search.score": 0.113759264, + "hotelId": "2", + "hotelName": "Roach Motel", + "description": "Cheapest hotel in town. Infact, a motel.", + "descriptionFr": "H\u00C3\u00B4tel le moins cher en ville. Infact, un motel.", + "category": "Budget", + "tags": [ + "motel", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": true, + "lastRenovationDate": "1982-04-28T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 49.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "34", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "9111fad1-7fc2-11ec-8677-74c63bed1137" + }, + "RequestBody": { + "count": true, + "search": "hotel" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "6173", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:37 GMT", + "elapsed-time": "14", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "9111fad1-7fc2-11ec-8677-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.count": 7, + "value": [ + { + "@search.score": 0.7960079, + "hotelId": "10", + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "descriptionFr": "\u00C3\u2030conomisez jusqu\u0027\u00C3\u00A0 50% sur les h\u00C3\u00B4tels traditionnels. WiFi gratuit, tr\u00C3\u00A8s bien situ\u00C3\u00A9 pr\u00C3\u00A8s du centre-ville, cuisine compl\u00C3\u00A8te, laveuse \u0026 s\u00C3\u00A9cheuse, support 24/7, bowling, centre de fitness et plus encore.", + "category": "Budget", + "tags": [ + "24-hour front desk service", + "coffee in lobby", + "restaurant" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1999-09-06T00:00:00Z", + "rating": 3, + "location": { + "type": "Point", + "coordinates": [ + -78.940483, + 35.90416 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "6910 Fayetteville Rd", + "city": "Durham", + "stateProvince": "NC", + "country": "USA", + "postalCode": "27713" + }, + "rooms": [ + { + "description": "Suite, 1 King Bed (Amenities)", + "descriptionFr": "Suite, 1 tr\u00C3\u00A8s grand lit (Services)", + "type": "Suite", + "baseRate": 2.44, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "coffee maker" + ] + }, + { + "description": "Budget Room, 1 Queen Bed (Amenities)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (Services)", + "type": "Budget Room", + "baseRate": 7.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": false, + "tags": [ + "coffee maker" + ] + } + ] + }, + { + "@search.score": 0.27958742, + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 5, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.26639014, + "hotelId": "3", + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "descriptionFr": "H\u00C3\u00B4tel le plus populaire en ville", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 46.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "4", + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "descriptionFr": "Assez bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "5", + "hotelName": "Comfy Place", + "description": "Another good hotel", + "descriptionFr": "Un autre bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "2012-08-12T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.11774718, + "hotelId": "9", + "hotelName": "Secret Point Motel", + "description": "The hotel is ideally located on the main commercial artery of the city in the heart of New York. A few minutes away is Time\u0027s Square and the historic centre of the city, as well as other places of interest that make New York one of America\u0027s most attractive and cosmopolitan cities.", + "descriptionFr": "L\u0027h\u00C3\u00B4tel est id\u00C3\u00A9alement situ\u00C3\u00A9 sur la principale art\u00C3\u00A8re commerciale de la ville en plein c\u00C5\u201Cur de New York. A quelques minutes se trouve la place du temps et le centre historique de la ville, ainsi que d\u0027autres lieux d\u0027int\u00C3\u00A9r\u00C3\u00AAt qui font de New York l\u0027une des villes les plus attractives et cosmopolites de l\u0027Am\u00C3\u00A9rique.", + "category": "Boutique", + "tags": [ + "pool", + "air conditioning", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1970-01-18T05:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -73.975403, + 40.760586 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "677 5th Ave", + "city": "New York", + "stateProvince": "NY", + "country": "USA", + "postalCode": "10022" + }, + "rooms": [ + { + "description": "Budget Room, 1 Queen Bed (Cityside)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (c\u00C3\u00B4t\u00C3\u00A9 ville)", + "type": "Budget Room", + "baseRate": 9.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd" + ] + }, + { + "description": "Budget Room, 1 King Bed (Mountain View)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 tr\u00C3\u00A8s grand lit (Mountain View)", + "type": "Budget Room", + "baseRate": 8.09, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd", + "jacuzzi tub" + ] + } + ] + }, + { + "@search.score": 0.113759264, + "hotelId": "2", + "hotelName": "Roach Motel", + "description": "Cheapest hotel in town. Infact, a motel.", + "descriptionFr": "H\u00C3\u00B4tel le moins cher en ville. Infact, un motel.", + "category": "Budget", + "tags": [ + "motel", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": true, + "lastRenovationDate": "1982-04-28T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 49.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "19", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "9127442a-7fc2-11ec-9400-74c63bed1137" + }, + "RequestBody": { + "search": "hotel" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "6156", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:37 GMT", + "elapsed-time": "14", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "9127442a-7fc2-11ec-9400-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.score": 0.7960079, + "hotelId": "10", + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "descriptionFr": "\u00C3\u2030conomisez jusqu\u0027\u00C3\u00A0 50% sur les h\u00C3\u00B4tels traditionnels. WiFi gratuit, tr\u00C3\u00A8s bien situ\u00C3\u00A9 pr\u00C3\u00A8s du centre-ville, cuisine compl\u00C3\u00A8te, laveuse \u0026 s\u00C3\u00A9cheuse, support 24/7, bowling, centre de fitness et plus encore.", + "category": "Budget", + "tags": [ + "24-hour front desk service", + "coffee in lobby", + "restaurant" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1999-09-06T00:00:00Z", + "rating": 3, + "location": { + "type": "Point", + "coordinates": [ + -78.940483, + 35.90416 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "6910 Fayetteville Rd", + "city": "Durham", + "stateProvince": "NC", + "country": "USA", + "postalCode": "27713" + }, + "rooms": [ + { + "description": "Suite, 1 King Bed (Amenities)", + "descriptionFr": "Suite, 1 tr\u00C3\u00A8s grand lit (Services)", + "type": "Suite", + "baseRate": 2.44, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "coffee maker" + ] + }, + { + "description": "Budget Room, 1 Queen Bed (Amenities)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (Services)", + "type": "Budget Room", + "baseRate": 7.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": false, + "tags": [ + "coffee maker" + ] + } + ] + }, + { + "@search.score": 0.27958742, + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 5, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.26639014, + "hotelId": "3", + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "descriptionFr": "H\u00C3\u00B4tel le plus populaire en ville", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 46.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "4", + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "descriptionFr": "Assez bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "5", + "hotelName": "Comfy Place", + "description": "Another good hotel", + "descriptionFr": "Un autre bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "2012-08-12T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.11774718, + "hotelId": "9", + "hotelName": "Secret Point Motel", + "description": "The hotel is ideally located on the main commercial artery of the city in the heart of New York. A few minutes away is Time\u0027s Square and the historic centre of the city, as well as other places of interest that make New York one of America\u0027s most attractive and cosmopolitan cities.", + "descriptionFr": "L\u0027h\u00C3\u00B4tel est id\u00C3\u00A9alement situ\u00C3\u00A9 sur la principale art\u00C3\u00A8re commerciale de la ville en plein c\u00C5\u201Cur de New York. A quelques minutes se trouve la place du temps et le centre historique de la ville, ainsi que d\u0027autres lieux d\u0027int\u00C3\u00A9r\u00C3\u00AAt qui font de New York l\u0027une des villes les plus attractives et cosmopolites de l\u0027Am\u00C3\u00A9rique.", + "category": "Boutique", + "tags": [ + "pool", + "air conditioning", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1970-01-18T05:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -73.975403, + 40.760586 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "677 5th Ave", + "city": "New York", + "stateProvince": "NY", + "country": "USA", + "postalCode": "10022" + }, + "rooms": [ + { + "description": "Budget Room, 1 Queen Bed (Cityside)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (c\u00C3\u00B4t\u00C3\u00A9 ville)", + "type": "Budget Room", + "baseRate": 9.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd" + ] + }, + { + "description": "Budget Room, 1 King Bed (Mountain View)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 tr\u00C3\u00A8s grand lit (Mountain View)", + "type": "Budget Room", + "baseRate": 8.09, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd", + "jacuzzi tub" + ] + } + ] + }, + { + "@search.score": 0.113759264, + "hotelId": "2", + "hotelName": "Roach Motel", + "description": "Cheapest hotel in town. Infact, a motel.", + "descriptionFr": "H\u00C3\u00B4tel le moins cher en ville. Infact, un motel.", + "category": "Budget", + "tags": [ + "motel", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": true, + "lastRenovationDate": "1982-04-28T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 49.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "44", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "913bccde-7fc2-11ec-8c71-74c63bed1137" + }, + "RequestBody": { + "minimumCoverage": 50.0, + "search": "hotel" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "6181", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:37 GMT", + "elapsed-time": "12", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "913bccde-7fc2-11ec-8c71-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@search.coverage": 100.0, + "value": [ + { + "@search.score": 0.7960079, + "hotelId": "10", + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "descriptionFr": "\u00C3\u2030conomisez jusqu\u0027\u00C3\u00A0 50% sur les h\u00C3\u00B4tels traditionnels. WiFi gratuit, tr\u00C3\u00A8s bien situ\u00C3\u00A9 pr\u00C3\u00A8s du centre-ville, cuisine compl\u00C3\u00A8te, laveuse \u0026 s\u00C3\u00A9cheuse, support 24/7, bowling, centre de fitness et plus encore.", + "category": "Budget", + "tags": [ + "24-hour front desk service", + "coffee in lobby", + "restaurant" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1999-09-06T00:00:00Z", + "rating": 3, + "location": { + "type": "Point", + "coordinates": [ + -78.940483, + 35.90416 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "6910 Fayetteville Rd", + "city": "Durham", + "stateProvince": "NC", + "country": "USA", + "postalCode": "27713" + }, + "rooms": [ + { + "description": "Suite, 1 King Bed (Amenities)", + "descriptionFr": "Suite, 1 tr\u00C3\u00A8s grand lit (Services)", + "type": "Suite", + "baseRate": 2.44, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "coffee maker" + ] + }, + { + "description": "Budget Room, 1 Queen Bed (Amenities)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (Services)", + "type": "Budget Room", + "baseRate": 7.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": false, + "tags": [ + "coffee maker" + ] + } + ] + }, + { + "@search.score": 0.27958742, + "hotelId": "1", + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "descriptionFr": "Meilleur h\u00C3\u00B4tel en ville si vous aimez les h\u00C3\u00B4tels de luxe. Ils ont une magnifique piscine \u00C3\u00A0 d\u00C3\u00A9bordement, un spa et un concierge tr\u00C3\u00A8s utile. L\u0027emplacement est parfait \u00E2\u20AC\u201C en plein centre, \u00C3\u00A0 proximit\u00C3\u00A9 de toutes les attractions touristiques. Nous recommandons fortement cet h\u00C3\u00B4tel.", + "category": "Luxury", + "tags": [ + "pool", + "view", + "wifi", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": false, + "lastRenovationDate": "2010-06-27T00:00:00Z", + "rating": 5, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 47.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.26639014, + "hotelId": "3", + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "descriptionFr": "H\u00C3\u00B4tel le plus populaire en ville", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 46.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "4", + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "descriptionFr": "Assez bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "1995-07-01T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.12874341, + "hotelId": "5", + "hotelName": "Comfy Place", + "description": "Another good hotel", + "descriptionFr": "Un autre bon h\u00C3\u00B4tel", + "category": "Budget", + "tags": [ + "wifi", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": false, + "lastRenovationDate": "2012-08-12T00:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 48.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + }, + { + "@search.score": 0.11774718, + "hotelId": "9", + "hotelName": "Secret Point Motel", + "description": "The hotel is ideally located on the main commercial artery of the city in the heart of New York. A few minutes away is Time\u0027s Square and the historic centre of the city, as well as other places of interest that make New York one of America\u0027s most attractive and cosmopolitan cities.", + "descriptionFr": "L\u0027h\u00C3\u00B4tel est id\u00C3\u00A9alement situ\u00C3\u00A9 sur la principale art\u00C3\u00A8re commerciale de la ville en plein c\u00C5\u201Cur de New York. A quelques minutes se trouve la place du temps et le centre historique de la ville, ainsi que d\u0027autres lieux d\u0027int\u00C3\u00A9r\u00C3\u00AAt qui font de New York l\u0027une des villes les plus attractives et cosmopolites de l\u0027Am\u00C3\u00A9rique.", + "category": "Boutique", + "tags": [ + "pool", + "air conditioning", + "concierge" + ], + "parkingIncluded": false, + "smokingAllowed": true, + "lastRenovationDate": "1970-01-18T05:00:00Z", + "rating": 4, + "location": { + "type": "Point", + "coordinates": [ + -73.975403, + 40.760586 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": { + "streetAddress": "677 5th Ave", + "city": "New York", + "stateProvince": "NY", + "country": "USA", + "postalCode": "10022" + }, + "rooms": [ + { + "description": "Budget Room, 1 Queen Bed (Cityside)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 grand lit (c\u00C3\u00B4t\u00C3\u00A9 ville)", + "type": "Budget Room", + "baseRate": 9.69, + "bedOptions": "1 Queen Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd" + ] + }, + { + "description": "Budget Room, 1 King Bed (Mountain View)", + "descriptionFr": "Chambre \u00C3\u2030conomique, 1 tr\u00C3\u00A8s grand lit (Mountain View)", + "type": "Budget Room", + "baseRate": 8.09, + "bedOptions": "1 King Bed", + "sleepsCount": 2, + "smokingAllowed": true, + "tags": [ + "vcr/dvd", + "jacuzzi tub" + ] + } + ] + }, + { + "@search.score": 0.113759264, + "hotelId": "2", + "hotelName": "Roach Motel", + "description": "Cheapest hotel in town. Infact, a motel.", + "descriptionFr": "H\u00C3\u00B4tel le moins cher en ville. Infact, un motel.", + "category": "Budget", + "tags": [ + "motel", + "budget" + ], + "parkingIncluded": true, + "smokingAllowed": true, + "lastRenovationDate": "1982-04-28T00:00:00Z", + "rating": 1, + "location": { + "type": "Point", + "coordinates": [ + -122.131577, + 49.678581 + ], + "crs": { + "type": "name", + "properties": { + "name": "EPSG:4326" + } + } + }, + "address": null, + "rooms": [] + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "62", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "9150140c-7fc2-11ec-bb0a-74c63bed1137" + }, + "RequestBody": { + "search": "WiFi", + "select": "hotelName,category,description" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "932", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:37 GMT", + "elapsed-time": "16", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "9150140c-7fc2-11ec-bb0a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.score": 1.3700507, + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "category": "Budget" + }, + { + "@search.score": 0.82257307, + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "category": "Luxury" + }, + { + "@search.score": 0.7373906, + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "category": "Budget" + }, + { + "@search.score": 0.42169982, + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "category": "Budget" + }, + { + "@search.score": 0.42169982, + "hotelName": "Comfy Place", + "description": "Another good hotel", + "category": "Budget" + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.search?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "86", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "9165406c-7fc2-11ec-8004-74c63bed1137" + }, + "RequestBody": { + "facets": [ + "category" + ], + "search": "WiFi", + "select": "hotelName,category,description" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1022", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:37 GMT", + "elapsed-time": "15", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "9165406c-7fc2-11ec-8004-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@search.facets": { + "category": [ + { + "count": 4, + "value": "Budget" + }, + { + "count": 1, + "value": "Luxury" + } + ] + }, + "value": [ + { + "@search.score": 1.3700507, + "hotelName": "Countryside Hotel", + "description": "Save up to 50% off traditional hotels. Free WiFi, great location near downtown, full kitchen, washer \u0026 dryer, 24/7 support, bowling alley, fitness center and more.", + "category": "Budget" + }, + { + "@search.score": 0.82257307, + "hotelName": "Fancy Stay", + "description": "Best hotel in town if you like luxury hotels. They have an amazing infinity pool, a spa, and a really helpful concierge. The location is perfect -- right downtown, close to all the tourist attractions. We highly recommend this hotel.", + "category": "Luxury" + }, + { + "@search.score": 0.7373906, + "hotelName": "EconoStay", + "description": "Very popular hotel in town", + "category": "Budget" + }, + { + "@search.score": 0.42169982, + "hotelName": "Express Rooms", + "description": "Pretty good hotel", + "category": "Budget" + }, + { + "@search.score": 0.42169982, + "hotelName": "Comfy Place", + "description": "Another good hotel", + "category": "Budget" + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.autocomplete?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "40", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "917a5519-7fc2-11ec-a925-74c63bed1137" + }, + "RequestBody": { + "search": "mot", + "suggesterName": "sg" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "52", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:37 GMT", + "elapsed-time": "10", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "917a5519-7fc2-11ec-a925-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "text": "motel", + "queryPlusText": "motel" + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027drgqefsg\u0027)/docs/search.post.suggest?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=none", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "40", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "9194a90d-7fc2-11ec-b298-74c63bed1137" + }, + "RequestBody": { + "search": "mot", + "suggesterName": "sg" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "137", + "Content-Type": "application/json; odata.metadata=none", + "Date": "Thu, 27 Jan 2022 22:43:37 GMT", + "elapsed-time": "23", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "9194a90d-7fc2-11ec-b298-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "value": [ + { + "@search.text": "Cheapest hotel in town. Infact, a motel.", + "hotelId": "2" + }, + { + "@search.text": "Secret Point Motel", + "hotelId": "9" + } + ] + } + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_autocomplete.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_autocomplete.yaml deleted file mode 100644 index e7381a7d8cd7..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_autocomplete.yaml +++ /dev/null @@ -1,50 +0,0 @@ -interactions: -- request: - body: '{"search": "mot", "suggesterName": "sg"}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '40' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searche2a413b7.search.windows.net/indexes('drgqefsg')/docs/search.post.autocomplete?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"text":"motel","queryPlusText":"motel"}]}' - headers: - cache-control: - - no-cache - content-length: - - '52' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:10:37 GMT - elapsed-time: - - '251' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 5d8254ab-0a7e-11ec-bab7-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_counts.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_counts.yaml deleted file mode 100644 index a4918a49beb7..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_counts.yaml +++ /dev/null @@ -1,192 +0,0 @@ -interactions: -- request: - body: '{"search": "hotel"}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '19' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search498015b5.search.windows.net/indexes('drgqefsg')/docs/search.post.search?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"@search.score":1.8955941,"hotelId":"10","hotelName":"Countryside - Hotel","description":"Save up to 50% off traditional hotels. Free WiFi, great - location near downtown, full kitchen, washer & dryer, 24/7 support, bowling - alley, fitness center and more.","descriptionFr":"\u00c3\u2030conomisez jusqu''\u00c3\u00a0 - 50% sur les h\u00c3\u00b4tels traditionnels. WiFi gratuit, tr\u00c3\u00a8s - bien situ\u00c3\u00a9 pr\u00c3\u00a8s du centre-ville, cuisine compl\u00c3\u00a8te, - laveuse & s\u00c3\u00a9cheuse, support 24/7, bowling, centre de fitness et - plus encore.","category":"Budget","tags":["24-hour front desk service","coffee - in lobby","restaurant"],"parkingIncluded":false,"smokingAllowed":true,"lastRenovationDate":"1999-09-06T00:00:00Z","rating":3,"location":{"type":"Point","coordinates":[-78.940483,35.90416],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":{"streetAddress":"6910 - Fayetteville Rd","city":"Durham","stateProvince":"NC","country":"USA","postalCode":"27713"},"rooms":[{"description":"Suite, - 1 King Bed (Amenities)","descriptionFr":"Suite, 1 tr\u00c3\u00a8s grand lit - (Services)","type":"Suite","baseRate":2.44,"bedOptions":"1 King Bed","sleepsCount":2,"smokingAllowed":true,"tags":["coffee - maker"]},{"description":"Budget Room, 1 Queen Bed (Amenities)","descriptionFr":"Chambre - \u00c3\u2030conomique, 1 grand lit (Services)","type":"Budget Room","baseRate":7.69,"bedOptions":"1 - Queen Bed","sleepsCount":2,"smokingAllowed":false,"tags":["coffee maker"]}]},{"@search.score":0.89701396,"hotelId":"3","hotelName":"EconoStay","description":"Very - popular hotel in town","descriptionFr":"H\u00c3\u00b4tel le plus populaire - en ville","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,46.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.89701396,"hotelId":"4","hotelName":"Express - Rooms","description":"Pretty good hotel","descriptionFr":"Assez bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.89701396,"hotelId":"5","hotelName":"Comfy - Place","description":"Another good hotel","descriptionFr":"Un autre bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"2012-08-12T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.8367443,"hotelId":"2","hotelName":"Roach - Motel","description":"Cheapest hotel in town. Infact, a motel.","descriptionFr":"H\u00c3\u00b4tel - le moins cher en ville. Infact, un motel.","category":"Budget","tags":["motel","budget"],"parkingIncluded":true,"smokingAllowed":true,"lastRenovationDate":"1982-04-28T00:00:00Z","rating":1,"location":{"type":"Point","coordinates":[-122.131577,49.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.74453783,"hotelId":"1","hotelName":"Fancy - Stay","description":"Best hotel in town if you like luxury hotels. They have - an amazing infinity pool, a spa, and a really helpful concierge. The location - is perfect -- right downtown, close to all the tourist attractions. We highly - recommend this hotel.","descriptionFr":"Meilleur h\u00c3\u00b4tel en ville - si vous aimez les h\u00c3\u00b4tels de luxe. Ils ont une magnifique piscine - \u00c3\u00a0 d\u00c3\u00a9bordement, un spa et un concierge tr\u00c3\u00a8s - utile. L''emplacement est parfait \u00e2\u20ac\u201c en plein centre, \u00c3\u00a0 - proximit\u00c3\u00a9 de toutes les attractions touristiques. Nous recommandons - fortement cet h\u00c3\u00b4tel.","category":"Luxury","tags":["pool","view","wifi","concierge"],"parkingIncluded":false,"smokingAllowed":false,"lastRenovationDate":"2010-06-27T00:00:00Z","rating":5,"location":{"type":"Point","coordinates":[-122.131577,47.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.28260264,"hotelId":"9","hotelName":"Secret - Point Motel","description":"The hotel is ideally located on the main commercial - artery of the city in the heart of New York. A few minutes away is Time''s - Square and the historic centre of the city, as well as other places of interest - that make New York one of America''s most attractive and cosmopolitan cities.","descriptionFr":"L''h\u00c3\u00b4tel - est id\u00c3\u00a9alement situ\u00c3\u00a9 sur la principale art\u00c3\u00a8re - commerciale de la ville en plein c\u00c5\u201cur de New York. A quelques minutes - se trouve la place du temps et le centre historique de la ville, ainsi que - d''autres lieux d''int\u00c3\u00a9r\u00c3\u00aat qui font de New York l''une - des villes les plus attractives et cosmopolites de l''Am\u00c3\u00a9rique.","category":"Boutique","tags":["pool","air - conditioning","concierge"],"parkingIncluded":false,"smokingAllowed":true,"lastRenovationDate":"1970-01-18T05:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-73.975403,40.760586],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":{"streetAddress":"677 - 5th Ave","city":"New York","stateProvince":"NY","country":"USA","postalCode":"10022"},"rooms":[{"description":"Budget - Room, 1 Queen Bed (Cityside)","descriptionFr":"Chambre \u00c3\u2030conomique, - 1 grand lit (c\u00c3\u00b4t\u00c3\u00a9 ville)","type":"Budget Room","baseRate":9.69,"bedOptions":"1 - Queen Bed","sleepsCount":2,"smokingAllowed":true,"tags":["vcr/dvd"]},{"description":"Budget - Room, 1 King Bed (Mountain View)","descriptionFr":"Chambre \u00c3\u2030conomique, - 1 tr\u00c3\u00a8s grand lit (Mountain View)","type":"Budget Room","baseRate":8.09,"bedOptions":"1 - King Bed","sleepsCount":2,"smokingAllowed":true,"tags":["vcr/dvd","jacuzzi - tub"]}]}]}' - headers: - cache-control: - - no-cache - content-length: - - '6154' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:10:50 GMT - elapsed-time: - - '66' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 650b25b5-0a7e-11ec-b8e9-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"count": true, "search": "hotel"}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '34' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search498015b5.search.windows.net/indexes('drgqefsg')/docs/search.post.search?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.count":7,"value":[{"@search.score":1.8955941,"hotelId":"10","hotelName":"Countryside - Hotel","description":"Save up to 50% off traditional hotels. Free WiFi, great - location near downtown, full kitchen, washer & dryer, 24/7 support, bowling - alley, fitness center and more.","descriptionFr":"\u00c3\u2030conomisez jusqu''\u00c3\u00a0 - 50% sur les h\u00c3\u00b4tels traditionnels. WiFi gratuit, tr\u00c3\u00a8s - bien situ\u00c3\u00a9 pr\u00c3\u00a8s du centre-ville, cuisine compl\u00c3\u00a8te, - laveuse & s\u00c3\u00a9cheuse, support 24/7, bowling, centre de fitness et - plus encore.","category":"Budget","tags":["24-hour front desk service","coffee - in lobby","restaurant"],"parkingIncluded":false,"smokingAllowed":true,"lastRenovationDate":"1999-09-06T00:00:00Z","rating":3,"location":{"type":"Point","coordinates":[-78.940483,35.90416],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":{"streetAddress":"6910 - Fayetteville Rd","city":"Durham","stateProvince":"NC","country":"USA","postalCode":"27713"},"rooms":[{"description":"Suite, - 1 King Bed (Amenities)","descriptionFr":"Suite, 1 tr\u00c3\u00a8s grand lit - (Services)","type":"Suite","baseRate":2.44,"bedOptions":"1 King Bed","sleepsCount":2,"smokingAllowed":true,"tags":["coffee - maker"]},{"description":"Budget Room, 1 Queen Bed (Amenities)","descriptionFr":"Chambre - \u00c3\u2030conomique, 1 grand lit (Services)","type":"Budget Room","baseRate":7.69,"bedOptions":"1 - Queen Bed","sleepsCount":2,"smokingAllowed":false,"tags":["coffee maker"]}]},{"@search.score":0.89701396,"hotelId":"3","hotelName":"EconoStay","description":"Very - popular hotel in town","descriptionFr":"H\u00c3\u00b4tel le plus populaire - en ville","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,46.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.89701396,"hotelId":"4","hotelName":"Express - Rooms","description":"Pretty good hotel","descriptionFr":"Assez bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.89701396,"hotelId":"5","hotelName":"Comfy - Place","description":"Another good hotel","descriptionFr":"Un autre bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"2012-08-12T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.8367443,"hotelId":"2","hotelName":"Roach - Motel","description":"Cheapest hotel in town. Infact, a motel.","descriptionFr":"H\u00c3\u00b4tel - le moins cher en ville. Infact, un motel.","category":"Budget","tags":["motel","budget"],"parkingIncluded":true,"smokingAllowed":true,"lastRenovationDate":"1982-04-28T00:00:00Z","rating":1,"location":{"type":"Point","coordinates":[-122.131577,49.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.74453783,"hotelId":"1","hotelName":"Fancy - Stay","description":"Best hotel in town if you like luxury hotels. They have - an amazing infinity pool, a spa, and a really helpful concierge. The location - is perfect -- right downtown, close to all the tourist attractions. We highly - recommend this hotel.","descriptionFr":"Meilleur h\u00c3\u00b4tel en ville - si vous aimez les h\u00c3\u00b4tels de luxe. Ils ont une magnifique piscine - \u00c3\u00a0 d\u00c3\u00a9bordement, un spa et un concierge tr\u00c3\u00a8s - utile. L''emplacement est parfait \u00e2\u20ac\u201c en plein centre, \u00c3\u00a0 - proximit\u00c3\u00a9 de toutes les attractions touristiques. Nous recommandons - fortement cet h\u00c3\u00b4tel.","category":"Luxury","tags":["pool","view","wifi","concierge"],"parkingIncluded":false,"smokingAllowed":false,"lastRenovationDate":"2010-06-27T00:00:00Z","rating":5,"location":{"type":"Point","coordinates":[-122.131577,47.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.28260264,"hotelId":"9","hotelName":"Secret - Point Motel","description":"The hotel is ideally located on the main commercial - artery of the city in the heart of New York. A few minutes away is Time''s - Square and the historic centre of the city, as well as other places of interest - that make New York one of America''s most attractive and cosmopolitan cities.","descriptionFr":"L''h\u00c3\u00b4tel - est id\u00c3\u00a9alement situ\u00c3\u00a9 sur la principale art\u00c3\u00a8re - commerciale de la ville en plein c\u00c5\u201cur de New York. A quelques minutes - se trouve la place du temps et le centre historique de la ville, ainsi que - d''autres lieux d''int\u00c3\u00a9r\u00c3\u00aat qui font de New York l''une - des villes les plus attractives et cosmopolites de l''Am\u00c3\u00a9rique.","category":"Boutique","tags":["pool","air - conditioning","concierge"],"parkingIncluded":false,"smokingAllowed":true,"lastRenovationDate":"1970-01-18T05:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-73.975403,40.760586],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":{"streetAddress":"677 - 5th Ave","city":"New York","stateProvince":"NY","country":"USA","postalCode":"10022"},"rooms":[{"description":"Budget - Room, 1 Queen Bed (Cityside)","descriptionFr":"Chambre \u00c3\u2030conomique, - 1 grand lit (c\u00c3\u00b4t\u00c3\u00a9 ville)","type":"Budget Room","baseRate":9.69,"bedOptions":"1 - Queen Bed","sleepsCount":2,"smokingAllowed":true,"tags":["vcr/dvd"]},{"description":"Budget - Room, 1 King Bed (Mountain View)","descriptionFr":"Chambre \u00c3\u2030conomique, - 1 tr\u00c3\u00a8s grand lit (Mountain View)","type":"Budget Room","baseRate":8.09,"bedOptions":"1 - King Bed","sleepsCount":2,"smokingAllowed":true,"tags":["vcr/dvd","jacuzzi - tub"]}]}]}' - headers: - cache-control: - - no-cache - content-length: - - '6171' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:10:50 GMT - elapsed-time: - - '9' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 653f6f31-0a7e-11ec-9461-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_coverage.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_coverage.yaml deleted file mode 100644 index f1f32467c6a1..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_coverage.yaml +++ /dev/null @@ -1,192 +0,0 @@ -interactions: -- request: - body: '{"search": "hotel"}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '19' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search75b81665.search.windows.net/indexes('drgqefsg')/docs/search.post.search?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"@search.score":1.8955941,"hotelId":"10","hotelName":"Countryside - Hotel","description":"Save up to 50% off traditional hotels. Free WiFi, great - location near downtown, full kitchen, washer & dryer, 24/7 support, bowling - alley, fitness center and more.","descriptionFr":"\u00c3\u2030conomisez jusqu''\u00c3\u00a0 - 50% sur les h\u00c3\u00b4tels traditionnels. WiFi gratuit, tr\u00c3\u00a8s - bien situ\u00c3\u00a9 pr\u00c3\u00a8s du centre-ville, cuisine compl\u00c3\u00a8te, - laveuse & s\u00c3\u00a9cheuse, support 24/7, bowling, centre de fitness et - plus encore.","category":"Budget","tags":["24-hour front desk service","coffee - in lobby","restaurant"],"parkingIncluded":false,"smokingAllowed":true,"lastRenovationDate":"1999-09-06T00:00:00Z","rating":3,"location":{"type":"Point","coordinates":[-78.940483,35.90416],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":{"streetAddress":"6910 - Fayetteville Rd","city":"Durham","stateProvince":"NC","country":"USA","postalCode":"27713"},"rooms":[{"description":"Suite, - 1 King Bed (Amenities)","descriptionFr":"Suite, 1 tr\u00c3\u00a8s grand lit - (Services)","type":"Suite","baseRate":2.44,"bedOptions":"1 King Bed","sleepsCount":2,"smokingAllowed":true,"tags":["coffee - maker"]},{"description":"Budget Room, 1 Queen Bed (Amenities)","descriptionFr":"Chambre - \u00c3\u2030conomique, 1 grand lit (Services)","type":"Budget Room","baseRate":7.69,"bedOptions":"1 - Queen Bed","sleepsCount":2,"smokingAllowed":false,"tags":["coffee maker"]}]},{"@search.score":0.89701396,"hotelId":"3","hotelName":"EconoStay","description":"Very - popular hotel in town","descriptionFr":"H\u00c3\u00b4tel le plus populaire - en ville","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,46.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.89701396,"hotelId":"4","hotelName":"Express - Rooms","description":"Pretty good hotel","descriptionFr":"Assez bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.89701396,"hotelId":"5","hotelName":"Comfy - Place","description":"Another good hotel","descriptionFr":"Un autre bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"2012-08-12T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.8367443,"hotelId":"2","hotelName":"Roach - Motel","description":"Cheapest hotel in town. Infact, a motel.","descriptionFr":"H\u00c3\u00b4tel - le moins cher en ville. Infact, un motel.","category":"Budget","tags":["motel","budget"],"parkingIncluded":true,"smokingAllowed":true,"lastRenovationDate":"1982-04-28T00:00:00Z","rating":1,"location":{"type":"Point","coordinates":[-122.131577,49.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.74453783,"hotelId":"1","hotelName":"Fancy - Stay","description":"Best hotel in town if you like luxury hotels. They have - an amazing infinity pool, a spa, and a really helpful concierge. The location - is perfect -- right downtown, close to all the tourist attractions. We highly - recommend this hotel.","descriptionFr":"Meilleur h\u00c3\u00b4tel en ville - si vous aimez les h\u00c3\u00b4tels de luxe. Ils ont une magnifique piscine - \u00c3\u00a0 d\u00c3\u00a9bordement, un spa et un concierge tr\u00c3\u00a8s - utile. L''emplacement est parfait \u00e2\u20ac\u201c en plein centre, \u00c3\u00a0 - proximit\u00c3\u00a9 de toutes les attractions touristiques. Nous recommandons - fortement cet h\u00c3\u00b4tel.","category":"Luxury","tags":["pool","view","wifi","concierge"],"parkingIncluded":false,"smokingAllowed":false,"lastRenovationDate":"2010-06-27T00:00:00Z","rating":5,"location":{"type":"Point","coordinates":[-122.131577,47.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.28260264,"hotelId":"9","hotelName":"Secret - Point Motel","description":"The hotel is ideally located on the main commercial - artery of the city in the heart of New York. A few minutes away is Time''s - Square and the historic centre of the city, as well as other places of interest - that make New York one of America''s most attractive and cosmopolitan cities.","descriptionFr":"L''h\u00c3\u00b4tel - est id\u00c3\u00a9alement situ\u00c3\u00a9 sur la principale art\u00c3\u00a8re - commerciale de la ville en plein c\u00c5\u201cur de New York. A quelques minutes - se trouve la place du temps et le centre historique de la ville, ainsi que - d''autres lieux d''int\u00c3\u00a9r\u00c3\u00aat qui font de New York l''une - des villes les plus attractives et cosmopolites de l''Am\u00c3\u00a9rique.","category":"Boutique","tags":["pool","air - conditioning","concierge"],"parkingIncluded":false,"smokingAllowed":true,"lastRenovationDate":"1970-01-18T05:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-73.975403,40.760586],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":{"streetAddress":"677 - 5th Ave","city":"New York","stateProvince":"NY","country":"USA","postalCode":"10022"},"rooms":[{"description":"Budget - Room, 1 Queen Bed (Cityside)","descriptionFr":"Chambre \u00c3\u2030conomique, - 1 grand lit (c\u00c3\u00b4t\u00c3\u00a9 ville)","type":"Budget Room","baseRate":9.69,"bedOptions":"1 - Queen Bed","sleepsCount":2,"smokingAllowed":true,"tags":["vcr/dvd"]},{"description":"Budget - Room, 1 King Bed (Mountain View)","descriptionFr":"Chambre \u00c3\u2030conomique, - 1 tr\u00c3\u00a8s grand lit (Mountain View)","type":"Budget Room","baseRate":8.09,"bedOptions":"1 - King Bed","sleepsCount":2,"smokingAllowed":true,"tags":["vcr/dvd","jacuzzi - tub"]}]}]}' - headers: - cache-control: - - no-cache - content-length: - - '6154' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:11:03 GMT - elapsed-time: - - '298' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 6d1a5ac5-0a7e-11ec-a45c-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"minimumCoverage": 50.0, "search": "hotel"}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '44' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search75b81665.search.windows.net/indexes('drgqefsg')/docs/search.post.search?api-version=2021-04-30-Preview - response: - body: - string: '{"@search.coverage":100.0,"value":[{"@search.score":1.8955941,"hotelId":"10","hotelName":"Countryside - Hotel","description":"Save up to 50% off traditional hotels. Free WiFi, great - location near downtown, full kitchen, washer & dryer, 24/7 support, bowling - alley, fitness center and more.","descriptionFr":"\u00c3\u2030conomisez jusqu''\u00c3\u00a0 - 50% sur les h\u00c3\u00b4tels traditionnels. WiFi gratuit, tr\u00c3\u00a8s - bien situ\u00c3\u00a9 pr\u00c3\u00a8s du centre-ville, cuisine compl\u00c3\u00a8te, - laveuse & s\u00c3\u00a9cheuse, support 24/7, bowling, centre de fitness et - plus encore.","category":"Budget","tags":["24-hour front desk service","coffee - in lobby","restaurant"],"parkingIncluded":false,"smokingAllowed":true,"lastRenovationDate":"1999-09-06T00:00:00Z","rating":3,"location":{"type":"Point","coordinates":[-78.940483,35.90416],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":{"streetAddress":"6910 - Fayetteville Rd","city":"Durham","stateProvince":"NC","country":"USA","postalCode":"27713"},"rooms":[{"description":"Suite, - 1 King Bed (Amenities)","descriptionFr":"Suite, 1 tr\u00c3\u00a8s grand lit - (Services)","type":"Suite","baseRate":2.44,"bedOptions":"1 King Bed","sleepsCount":2,"smokingAllowed":true,"tags":["coffee - maker"]},{"description":"Budget Room, 1 Queen Bed (Amenities)","descriptionFr":"Chambre - \u00c3\u2030conomique, 1 grand lit (Services)","type":"Budget Room","baseRate":7.69,"bedOptions":"1 - Queen Bed","sleepsCount":2,"smokingAllowed":false,"tags":["coffee maker"]}]},{"@search.score":0.89701396,"hotelId":"3","hotelName":"EconoStay","description":"Very - popular hotel in town","descriptionFr":"H\u00c3\u00b4tel le plus populaire - en ville","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,46.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.89701396,"hotelId":"4","hotelName":"Express - Rooms","description":"Pretty good hotel","descriptionFr":"Assez bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.89701396,"hotelId":"5","hotelName":"Comfy - Place","description":"Another good hotel","descriptionFr":"Un autre bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"2012-08-12T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.8367443,"hotelId":"2","hotelName":"Roach - Motel","description":"Cheapest hotel in town. Infact, a motel.","descriptionFr":"H\u00c3\u00b4tel - le moins cher en ville. Infact, un motel.","category":"Budget","tags":["motel","budget"],"parkingIncluded":true,"smokingAllowed":true,"lastRenovationDate":"1982-04-28T00:00:00Z","rating":1,"location":{"type":"Point","coordinates":[-122.131577,49.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.74453783,"hotelId":"1","hotelName":"Fancy - Stay","description":"Best hotel in town if you like luxury hotels. They have - an amazing infinity pool, a spa, and a really helpful concierge. The location - is perfect -- right downtown, close to all the tourist attractions. We highly - recommend this hotel.","descriptionFr":"Meilleur h\u00c3\u00b4tel en ville - si vous aimez les h\u00c3\u00b4tels de luxe. Ils ont une magnifique piscine - \u00c3\u00a0 d\u00c3\u00a9bordement, un spa et un concierge tr\u00c3\u00a8s - utile. L''emplacement est parfait \u00e2\u20ac\u201c en plein centre, \u00c3\u00a0 - proximit\u00c3\u00a9 de toutes les attractions touristiques. Nous recommandons - fortement cet h\u00c3\u00b4tel.","category":"Luxury","tags":["pool","view","wifi","concierge"],"parkingIncluded":false,"smokingAllowed":false,"lastRenovationDate":"2010-06-27T00:00:00Z","rating":5,"location":{"type":"Point","coordinates":[-122.131577,47.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.28260264,"hotelId":"9","hotelName":"Secret - Point Motel","description":"The hotel is ideally located on the main commercial - artery of the city in the heart of New York. A few minutes away is Time''s - Square and the historic centre of the city, as well as other places of interest - that make New York one of America''s most attractive and cosmopolitan cities.","descriptionFr":"L''h\u00c3\u00b4tel - est id\u00c3\u00a9alement situ\u00c3\u00a9 sur la principale art\u00c3\u00a8re - commerciale de la ville en plein c\u00c5\u201cur de New York. A quelques minutes - se trouve la place du temps et le centre historique de la ville, ainsi que - d''autres lieux d''int\u00c3\u00a9r\u00c3\u00aat qui font de New York l''une - des villes les plus attractives et cosmopolites de l''Am\u00c3\u00a9rique.","category":"Boutique","tags":["pool","air - conditioning","concierge"],"parkingIncluded":false,"smokingAllowed":true,"lastRenovationDate":"1970-01-18T05:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-73.975403,40.760586],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":{"streetAddress":"677 - 5th Ave","city":"New York","stateProvince":"NY","country":"USA","postalCode":"10022"},"rooms":[{"description":"Budget - Room, 1 Queen Bed (Cityside)","descriptionFr":"Chambre \u00c3\u2030conomique, - 1 grand lit (c\u00c3\u00b4t\u00c3\u00a9 ville)","type":"Budget Room","baseRate":9.69,"bedOptions":"1 - Queen Bed","sleepsCount":2,"smokingAllowed":true,"tags":["vcr/dvd"]},{"description":"Budget - Room, 1 King Bed (Mountain View)","descriptionFr":"Chambre \u00c3\u2030conomique, - 1 tr\u00c3\u00a8s grand lit (Mountain View)","type":"Budget Room","baseRate":8.09,"bedOptions":"1 - King Bed","sleepsCount":2,"smokingAllowed":true,"tags":["vcr/dvd","jacuzzi - tub"]}]}]}' - headers: - cache-control: - - no-cache - content-length: - - '6179' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:11:03 GMT - elapsed-time: - - '9' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 6d6eb962-0a7e-11ec-97c9-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_facets_none.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_facets_none.yaml deleted file mode 100644 index 19df06de20c0..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_facets_none.yaml +++ /dev/null @@ -1,60 +0,0 @@ -interactions: -- request: - body: '{"search": "WiFi", "select": "hotelName,category,description"}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '62' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchbad5179e.search.windows.net/indexes('drgqefsg')/docs/search.post.search?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"@search.score":2.534638,"hotelName":"Countryside Hotel","description":"Save - up to 50% off traditional hotels. Free WiFi, great location near downtown, - full kitchen, washer & dryer, 24/7 support, bowling alley, fitness center - and more.","category":"Budget"},{"@search.score":1.0225849,"hotelName":"EconoStay","description":"Very - popular hotel in town","category":"Budget"},{"@search.score":1.0225849,"hotelName":"Express - Rooms","description":"Pretty good hotel","category":"Budget"},{"@search.score":1.0225849,"hotelName":"Comfy - Place","description":"Another good hotel","category":"Budget"},{"@search.score":0.7987757,"hotelName":"Fancy - Stay","description":"Best hotel in town if you like luxury hotels. They have - an amazing infinity pool, a spa, and a really helpful concierge. The location - is perfect -- right downtown, close to all the tourist attractions. We highly - recommend this hotel.","category":"Luxury"}]}' - headers: - cache-control: - - no-cache - content-length: - - '928' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:11:17 GMT - elapsed-time: - - '106' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 75fc1941-0a7e-11ec-9c47-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_facets_result.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_facets_result.yaml deleted file mode 100644 index 8512b383c310..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_facets_result.yaml +++ /dev/null @@ -1,60 +0,0 @@ -interactions: -- request: - body: '{"facets": ["category"], "search": "WiFi", "select": "hotelName,category,description"}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '86' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searcheb87188d.search.windows.net/indexes('drgqefsg')/docs/search.post.search?api-version=2021-04-30-Preview - response: - body: - string: '{"@search.facets":{"category":[{"count":4,"value":"Budget"},{"count":1,"value":"Luxury"}]},"value":[{"@search.score":2.534638,"hotelName":"Countryside - Hotel","description":"Save up to 50% off traditional hotels. Free WiFi, great - location near downtown, full kitchen, washer & dryer, 24/7 support, bowling - alley, fitness center and more.","category":"Budget"},{"@search.score":1.0225849,"hotelName":"EconoStay","description":"Very - popular hotel in town","category":"Budget"},{"@search.score":1.0225849,"hotelName":"Express - Rooms","description":"Pretty good hotel","category":"Budget"},{"@search.score":1.0225849,"hotelName":"Comfy - Place","description":"Another good hotel","category":"Budget"},{"@search.score":0.7987757,"hotelName":"Fancy - Stay","description":"Best hotel in town if you like luxury hotels. They have - an amazing infinity pool, a spa, and a really helpful concierge. The location - is perfect -- right downtown, close to all the tourist attractions. We highly - recommend this hotel.","category":"Luxury"}]}' - headers: - cache-control: - - no-cache - content-length: - - '1018' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:11:32 GMT - elapsed-time: - - '337' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 7e38bcd8-0a7e-11ec-a88b-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_filter.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_filter.yaml deleted file mode 100644 index 6883ab9e77aa..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_filter.yaml +++ /dev/null @@ -1,57 +0,0 @@ -interactions: -- request: - body: '{"filter": "category eq ''Budget''", "orderby": "hotelName desc", "search": - "WiFi", "select": "hotelName,category,description"}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '125' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search4943159f.search.windows.net/indexes('drgqefsg')/docs/search.post.search?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"@search.score":1.0225849,"hotelName":"Express Rooms","description":"Pretty - good hotel","category":"Budget"},{"@search.score":1.0225849,"hotelName":"EconoStay","description":"Very - popular hotel in town","category":"Budget"},{"@search.score":2.534638,"hotelName":"Countryside - Hotel","description":"Save up to 50% off traditional hotels. Free WiFi, great - location near downtown, full kitchen, washer & dryer, 24/7 support, bowling - alley, fitness center and more.","category":"Budget"},{"@search.score":1.0225849,"hotelName":"Comfy - Place","description":"Another good hotel","category":"Budget"}]}' - headers: - cache-control: - - no-cache - content-length: - - '605' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:11:47 GMT - elapsed-time: - - '113' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 86e6e201-0a7e-11ec-8bfd-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_filter_array.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_filter_array.yaml deleted file mode 100644 index 135bec6e63d0..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_filter_array.yaml +++ /dev/null @@ -1,57 +0,0 @@ -interactions: -- request: - body: '{"filter": "category eq ''Budget''", "orderby": "hotelName desc", "search": - "WiFi", "select": "hotelName,category,description"}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '125' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchd375181d.search.windows.net/indexes('drgqefsg')/docs/search.post.search?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"@search.score":1.0225849,"hotelName":"Express Rooms","description":"Pretty - good hotel","category":"Budget"},{"@search.score":1.0225849,"hotelName":"EconoStay","description":"Very - popular hotel in town","category":"Budget"},{"@search.score":2.534638,"hotelName":"Countryside - Hotel","description":"Save up to 50% off traditional hotels. Free WiFi, great - location near downtown, full kitchen, washer & dryer, 24/7 support, bowling - alley, fitness center and more.","category":"Budget"},{"@search.score":1.0225849,"hotelName":"Comfy - Place","description":"Another good hotel","category":"Budget"}]}' - headers: - cache-control: - - no-cache - content-length: - - '605' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:12:01 GMT - elapsed-time: - - '16' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 8f70c3bd-0a7e-11ec-ab4f-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_simple.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_simple.yaml deleted file mode 100644 index 30301f7f7e90..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_simple.yaml +++ /dev/null @@ -1,165 +0,0 @@ -interactions: -- request: - body: '{"search": "hotel"}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '19' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search498a15a3.search.windows.net/indexes('drgqefsg')/docs/search.post.search?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"@search.score":1.8955941,"hotelId":"10","hotelName":"Countryside - Hotel","description":"Save up to 50% off traditional hotels. Free WiFi, great - location near downtown, full kitchen, washer & dryer, 24/7 support, bowling - alley, fitness center and more.","descriptionFr":"\u00c3\u2030conomisez jusqu''\u00c3\u00a0 - 50% sur les h\u00c3\u00b4tels traditionnels. WiFi gratuit, tr\u00c3\u00a8s - bien situ\u00c3\u00a9 pr\u00c3\u00a8s du centre-ville, cuisine compl\u00c3\u00a8te, - laveuse & s\u00c3\u00a9cheuse, support 24/7, bowling, centre de fitness et - plus encore.","category":"Budget","tags":["24-hour front desk service","coffee - in lobby","restaurant"],"parkingIncluded":false,"smokingAllowed":true,"lastRenovationDate":"1999-09-06T00:00:00Z","rating":3,"location":{"type":"Point","coordinates":[-78.940483,35.90416],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":{"streetAddress":"6910 - Fayetteville Rd","city":"Durham","stateProvince":"NC","country":"USA","postalCode":"27713"},"rooms":[{"description":"Suite, - 1 King Bed (Amenities)","descriptionFr":"Suite, 1 tr\u00c3\u00a8s grand lit - (Services)","type":"Suite","baseRate":2.44,"bedOptions":"1 King Bed","sleepsCount":2,"smokingAllowed":true,"tags":["coffee - maker"]},{"description":"Budget Room, 1 Queen Bed (Amenities)","descriptionFr":"Chambre - \u00c3\u2030conomique, 1 grand lit (Services)","type":"Budget Room","baseRate":7.69,"bedOptions":"1 - Queen Bed","sleepsCount":2,"smokingAllowed":false,"tags":["coffee maker"]}]},{"@search.score":0.89701396,"hotelId":"3","hotelName":"EconoStay","description":"Very - popular hotel in town","descriptionFr":"H\u00c3\u00b4tel le plus populaire - en ville","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,46.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.89701396,"hotelId":"4","hotelName":"Express - Rooms","description":"Pretty good hotel","descriptionFr":"Assez bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.89701396,"hotelId":"5","hotelName":"Comfy - Place","description":"Another good hotel","descriptionFr":"Un autre bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"2012-08-12T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.8367443,"hotelId":"2","hotelName":"Roach - Motel","description":"Cheapest hotel in town. Infact, a motel.","descriptionFr":"H\u00c3\u00b4tel - le moins cher en ville. Infact, un motel.","category":"Budget","tags":["motel","budget"],"parkingIncluded":true,"smokingAllowed":true,"lastRenovationDate":"1982-04-28T00:00:00Z","rating":1,"location":{"type":"Point","coordinates":[-122.131577,49.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.74453783,"hotelId":"1","hotelName":"Fancy - Stay","description":"Best hotel in town if you like luxury hotels. They have - an amazing infinity pool, a spa, and a really helpful concierge. The location - is perfect -- right downtown, close to all the tourist attractions. We highly - recommend this hotel.","descriptionFr":"Meilleur h\u00c3\u00b4tel en ville - si vous aimez les h\u00c3\u00b4tels de luxe. Ils ont une magnifique piscine - \u00c3\u00a0 d\u00c3\u00a9bordement, un spa et un concierge tr\u00c3\u00a8s - utile. L''emplacement est parfait \u00e2\u20ac\u201c en plein centre, \u00c3\u00a0 - proximit\u00c3\u00a9 de toutes les attractions touristiques. Nous recommandons - fortement cet h\u00c3\u00b4tel.","category":"Luxury","tags":["pool","view","wifi","concierge"],"parkingIncluded":false,"smokingAllowed":false,"lastRenovationDate":"2010-06-27T00:00:00Z","rating":5,"location":{"type":"Point","coordinates":[-122.131577,47.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.28260264,"hotelId":"9","hotelName":"Secret - Point Motel","description":"The hotel is ideally located on the main commercial - artery of the city in the heart of New York. A few minutes away is Time''s - Square and the historic centre of the city, as well as other places of interest - that make New York one of America''s most attractive and cosmopolitan cities.","descriptionFr":"L''h\u00c3\u00b4tel - est id\u00c3\u00a9alement situ\u00c3\u00a9 sur la principale art\u00c3\u00a8re - commerciale de la ville en plein c\u00c5\u201cur de New York. A quelques minutes - se trouve la place du temps et le centre historique de la ville, ainsi que - d''autres lieux d''int\u00c3\u00a9r\u00c3\u00aat qui font de New York l''une - des villes les plus attractives et cosmopolites de l''Am\u00c3\u00a9rique.","category":"Boutique","tags":["pool","air - conditioning","concierge"],"parkingIncluded":false,"smokingAllowed":true,"lastRenovationDate":"1970-01-18T05:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-73.975403,40.760586],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":{"streetAddress":"677 - 5th Ave","city":"New York","stateProvince":"NY","country":"USA","postalCode":"10022"},"rooms":[{"description":"Budget - Room, 1 Queen Bed (Cityside)","descriptionFr":"Chambre \u00c3\u2030conomique, - 1 grand lit (c\u00c3\u00b4t\u00c3\u00a9 ville)","type":"Budget Room","baseRate":9.69,"bedOptions":"1 - Queen Bed","sleepsCount":2,"smokingAllowed":true,"tags":["vcr/dvd"]},{"description":"Budget - Room, 1 King Bed (Mountain View)","descriptionFr":"Chambre \u00c3\u2030conomique, - 1 tr\u00c3\u00a8s grand lit (Mountain View)","type":"Budget Room","baseRate":8.09,"bedOptions":"1 - King Bed","sleepsCount":2,"smokingAllowed":true,"tags":["vcr/dvd","jacuzzi - tub"]}]}]}' - headers: - cache-control: - - no-cache - content-length: - - '6154' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:12:15 GMT - elapsed-time: - - '138' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 97e362f7-0a7e-11ec-9892-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"search": "motel"}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '19' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search498a15a3.search.windows.net/indexes('drgqefsg')/docs/search.post.search?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"@search.score":8.535209,"hotelId":"2","hotelName":"Roach - Motel","description":"Cheapest hotel in town. Infact, a motel.","descriptionFr":"H\u00c3\u00b4tel - le moins cher en ville. Infact, un motel.","category":"Budget","tags":["motel","budget"],"parkingIncluded":true,"smokingAllowed":true,"lastRenovationDate":"1982-04-28T00:00:00Z","rating":1,"location":{"type":"Point","coordinates":[-122.131577,49.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.8858137,"hotelId":"9","hotelName":"Secret - Point Motel","description":"The hotel is ideally located on the main commercial - artery of the city in the heart of New York. A few minutes away is Time''s - Square and the historic centre of the city, as well as other places of interest - that make New York one of America''s most attractive and cosmopolitan cities.","descriptionFr":"L''h\u00c3\u00b4tel - est id\u00c3\u00a9alement situ\u00c3\u00a9 sur la principale art\u00c3\u00a8re - commerciale de la ville en plein c\u00c5\u201cur de New York. A quelques minutes - se trouve la place du temps et le centre historique de la ville, ainsi que - d''autres lieux d''int\u00c3\u00a9r\u00c3\u00aat qui font de New York l''une - des villes les plus attractives et cosmopolites de l''Am\u00c3\u00a9rique.","category":"Boutique","tags":["pool","air - conditioning","concierge"],"parkingIncluded":false,"smokingAllowed":true,"lastRenovationDate":"1970-01-18T05:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-73.975403,40.760586],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":{"streetAddress":"677 - 5th Ave","city":"New York","stateProvince":"NY","country":"USA","postalCode":"10022"},"rooms":[{"description":"Budget - Room, 1 Queen Bed (Cityside)","descriptionFr":"Chambre \u00c3\u2030conomique, - 1 grand lit (c\u00c3\u00b4t\u00c3\u00a9 ville)","type":"Budget Room","baseRate":9.69,"bedOptions":"1 - Queen Bed","sleepsCount":2,"smokingAllowed":true,"tags":["vcr/dvd"]},{"description":"Budget - Room, 1 King Bed (Mountain View)","descriptionFr":"Chambre \u00c3\u2030conomique, - 1 tr\u00c3\u00a8s grand lit (Mountain View)","type":"Budget Room","baseRate":8.09,"bedOptions":"1 - King Bed","sleepsCount":2,"smokingAllowed":true,"tags":["vcr/dvd","jacuzzi - tub"]}]}]}' - headers: - cache-control: - - no-cache - content-length: - - '2275' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:12:15 GMT - elapsed-time: - - '7' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 98173e60-0a7e-11ec-a2ac-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_simple_with_top.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_simple_with_top.yaml deleted file mode 100644 index dda86003fa10..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_get_search_simple_with_top.yaml +++ /dev/null @@ -1,135 +0,0 @@ -interactions: -- request: - body: '{"search": "hotel", "top": 3}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '29' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search1f281970.search.windows.net/indexes('drgqefsg')/docs/search.post.search?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"@search.score":1.8955941,"hotelId":"10","hotelName":"Countryside - Hotel","description":"Save up to 50% off traditional hotels. Free WiFi, great - location near downtown, full kitchen, washer & dryer, 24/7 support, bowling - alley, fitness center and more.","descriptionFr":"\u00c3\u2030conomisez jusqu''\u00c3\u00a0 - 50% sur les h\u00c3\u00b4tels traditionnels. WiFi gratuit, tr\u00c3\u00a8s - bien situ\u00c3\u00a9 pr\u00c3\u00a8s du centre-ville, cuisine compl\u00c3\u00a8te, - laveuse & s\u00c3\u00a9cheuse, support 24/7, bowling, centre de fitness et - plus encore.","category":"Budget","tags":["24-hour front desk service","coffee - in lobby","restaurant"],"parkingIncluded":false,"smokingAllowed":true,"lastRenovationDate":"1999-09-06T00:00:00Z","rating":3,"location":{"type":"Point","coordinates":[-78.940483,35.90416],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":{"streetAddress":"6910 - Fayetteville Rd","city":"Durham","stateProvince":"NC","country":"USA","postalCode":"27713"},"rooms":[{"description":"Suite, - 1 King Bed (Amenities)","descriptionFr":"Suite, 1 tr\u00c3\u00a8s grand lit - (Services)","type":"Suite","baseRate":2.44,"bedOptions":"1 King Bed","sleepsCount":2,"smokingAllowed":true,"tags":["coffee - maker"]},{"description":"Budget Room, 1 Queen Bed (Amenities)","descriptionFr":"Chambre - \u00c3\u2030conomique, 1 grand lit (Services)","type":"Budget Room","baseRate":7.69,"bedOptions":"1 - Queen Bed","sleepsCount":2,"smokingAllowed":false,"tags":["coffee maker"]}]},{"@search.score":0.89701396,"hotelId":"3","hotelName":"EconoStay","description":"Very - popular hotel in town","descriptionFr":"H\u00c3\u00b4tel le plus populaire - en ville","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,46.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.89701396,"hotelId":"4","hotelName":"Express - Rooms","description":"Pretty good hotel","descriptionFr":"Assez bon h\u00c3\u00b4tel","category":"Budget","tags":["wifi","budget"],"parkingIncluded":true,"smokingAllowed":false,"lastRenovationDate":"1995-07-01T00:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-122.131577,48.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]}]}' - headers: - cache-control: - - no-cache - content-length: - - '2414' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:12:29 GMT - elapsed-time: - - '27' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - a0612520-0a7e-11ec-b5ec-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"search": "motel", "top": 3}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '29' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search1f281970.search.windows.net/indexes('drgqefsg')/docs/search.post.search?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"@search.score":8.535209,"hotelId":"2","hotelName":"Roach - Motel","description":"Cheapest hotel in town. Infact, a motel.","descriptionFr":"H\u00c3\u00b4tel - le moins cher en ville. Infact, un motel.","category":"Budget","tags":["motel","budget"],"parkingIncluded":true,"smokingAllowed":true,"lastRenovationDate":"1982-04-28T00:00:00Z","rating":1,"location":{"type":"Point","coordinates":[-122.131577,49.678581],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":null,"rooms":[]},{"@search.score":0.8858137,"hotelId":"9","hotelName":"Secret - Point Motel","description":"The hotel is ideally located on the main commercial - artery of the city in the heart of New York. A few minutes away is Time''s - Square and the historic centre of the city, as well as other places of interest - that make New York one of America''s most attractive and cosmopolitan cities.","descriptionFr":"L''h\u00c3\u00b4tel - est id\u00c3\u00a9alement situ\u00c3\u00a9 sur la principale art\u00c3\u00a8re - commerciale de la ville en plein c\u00c5\u201cur de New York. A quelques minutes - se trouve la place du temps et le centre historique de la ville, ainsi que - d''autres lieux d''int\u00c3\u00a9r\u00c3\u00aat qui font de New York l''une - des villes les plus attractives et cosmopolites de l''Am\u00c3\u00a9rique.","category":"Boutique","tags":["pool","air - conditioning","concierge"],"parkingIncluded":false,"smokingAllowed":true,"lastRenovationDate":"1970-01-18T05:00:00Z","rating":4,"location":{"type":"Point","coordinates":[-73.975403,40.760586],"crs":{"type":"name","properties":{"name":"EPSG:4326"}}},"address":{"streetAddress":"677 - 5th Ave","city":"New York","stateProvince":"NY","country":"USA","postalCode":"10022"},"rooms":[{"description":"Budget - Room, 1 Queen Bed (Cityside)","descriptionFr":"Chambre \u00c3\u2030conomique, - 1 grand lit (c\u00c3\u00b4t\u00c3\u00a9 ville)","type":"Budget Room","baseRate":9.69,"bedOptions":"1 - Queen Bed","sleepsCount":2,"smokingAllowed":true,"tags":["vcr/dvd"]},{"description":"Budget - Room, 1 King Bed (Mountain View)","descriptionFr":"Chambre \u00c3\u2030conomique, - 1 tr\u00c3\u00a8s grand lit (Mountain View)","type":"Budget Room","baseRate":8.09,"bedOptions":"1 - King Bed","sleepsCount":2,"smokingAllowed":true,"tags":["vcr/dvd","jacuzzi - tub"]}]}]}' - headers: - cache-control: - - no-cache - content-length: - - '2275' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:12:29 GMT - elapsed-time: - - '19' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - a08a8e53-0a7e-11ec-a0ee-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_suggest.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_suggest.yaml deleted file mode 100644 index 94d40d0785c6..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_client_search_live.test_suggest.yaml +++ /dev/null @@ -1,51 +0,0 @@ -interactions: -- request: - body: '{"search": "mot", "suggesterName": "sg"}' - headers: - Accept: - - application/json;odata.metadata=none - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '40' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search846911a7.search.windows.net/indexes('drgqefsg')/docs/search.post.suggest?api-version=2021-04-30-Preview - response: - body: - string: '{"value":[{"@search.text":"Cheapest hotel in town. Infact, a motel.","hotelId":"2"},{"@search.text":"Secret - Point Motel","hotelId":"9"}]}' - headers: - cache-control: - - no-cache - content-length: - - '137' - content-type: - - application/json; odata.metadata=none - date: - - Tue, 31 Aug 2021 17:12:44 GMT - elapsed-time: - - '78' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - a941af45-0a7e-11ec-9d92-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.pyTestSearchClientDataSourcestest_data_source.json b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.pyTestSearchClientDataSourcestest_data_source.json new file mode 100644 index 000000000000..2ccb42980df2 --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.pyTestSearchClientDataSourcestest_data_source.json @@ -0,0 +1,1445 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "226", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "7871878c-7fc2-11ec-ba96-74c63bed1137" + }, + "RequestBody": { + "name": "create", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "400", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:56 GMT", + "elapsed-time": "34", + "ETag": "W/\u00220x8D9E1E65CDCE69A\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027create\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "7871878c-7fc2-11ec-ba96-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E65CDCE69A\u0022", + "name": "create", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "226", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "78e2677b-7fc2-11ec-97ed-74c63bed1137" + }, + "RequestBody": { + "name": "delete", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "400", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:56 GMT", + "elapsed-time": "34", + "ETag": "W/\u00220x8D9E1E65CF880E3\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027delete\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "78e2677b-7fc2-11ec-97ed-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E65CF880E3\u0022", + "name": "delete", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "78f9ecfc-7fc2-11ec-9fbd-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "710", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:56 GMT", + "elapsed-time": "40", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "78f9ecfc-7fc2-11ec-9fbd-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E65CDCE69A\u0022", + "name": "create", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E65CF880E3\u0022", + "name": "delete", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources(\u0027delete\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "7911aba6-7fc2-11ec-b9cd-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:42:56 GMT", + "elapsed-time": "20", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "7911aba6-7fc2-11ec-b9cd-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "7926f3f8-7fc2-11ec-a4a9-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "404", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:56 GMT", + "elapsed-time": "12", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "7926f3f8-7fc2-11ec-a4a9-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E65CDCE69A\u0022", + "name": "create", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "223", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "793a3a60-7fc2-11ec-a32a-74c63bed1137" + }, + "RequestBody": { + "name": "get", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "397", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:56 GMT", + "elapsed-time": "34", + "ETag": "W/\u00220x8D9E1E65D4FE2D0\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027get\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "793a3a60-7fc2-11ec-a32a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E65D4FE2D0\u0022", + "name": "get", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources(\u0027get\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "795199bc-7fc2-11ec-b8d9-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "397", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:56 GMT", + "elapsed-time": "8", + "ETag": "W/\u00220x8D9E1E65D4FE2D0\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "795199bc-7fc2-11ec-b8d9-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E65D4FE2D0\u0022", + "name": "get", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "224", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "79657061-7fc2-11ec-8cc0-74c63bed1137" + }, + "RequestBody": { + "name": "list", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "398", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:57 GMT", + "elapsed-time": "51", + "ETag": "W/\u00220x8D9E1E65D7BA75A\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027list\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "79657061-7fc2-11ec-8cc0-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E65D7BA75A\u0022", + "name": "list", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "225", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "797fc8d9-7fc2-11ec-883b-74c63bed1137" + }, + "RequestBody": { + "name": "list2", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "399", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:57 GMT", + "elapsed-time": "36", + "ETag": "W/\u00220x8D9E1E65D9D0D1D\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027list2\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "797fc8d9-7fc2-11ec-883b-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E65D9D0D1D\u0022", + "name": "list2", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "799efb22-7fc2-11ec-ba0a-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1316", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:57 GMT", + "elapsed-time": "26", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "799efb22-7fc2-11ec-ba0a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E65CDCE69A\u0022", + "name": "create", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E65D4FE2D0\u0022", + "name": "get", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E65D7BA75A\u0022", + "name": "list", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E65D9D0D1D\u0022", + "name": "list2", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "223", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "79b537a3-7fc2-11ec-9cc5-74c63bed1137" + }, + "RequestBody": { + "name": "cou", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "397", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:57 GMT", + "elapsed-time": "37", + "ETag": "W/\u00220x8D9E1E65DD2942D\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027cou\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "79b537a3-7fc2-11ec-9cc5-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E65DD2942D\u0022", + "name": "cou", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "79d46c12-7fc2-11ec-9cdf-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1619", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:57 GMT", + "elapsed-time": "32", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "79d46c12-7fc2-11ec-9cdf-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E65DD2942D\u0022", + "name": "cou", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E65CDCE69A\u0022", + "name": "create", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E65D4FE2D0\u0022", + "name": "get", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E65D7BA75A\u0022", + "name": "list", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E65D9D0D1D\u0022", + "name": "list2", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources(\u0027cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "249", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "79eb2ea1-7fc2-11ec-b801-74c63bed1137" + }, + "RequestBody": { + "name": "cou", + "description": "updated", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "402", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:57 GMT", + "elapsed-time": "30", + "ETag": "W/\u00220x8D9E1E65E0709F5\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "79eb2ea1-7fc2-11ec-b801-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E65E0709F5\u0022", + "name": "cou", + "description": "updated", + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "7a084edc-7fc2-11ec-84c9-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1624", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:58 GMT", + "elapsed-time": "30", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "7a084edc-7fc2-11ec-84c9-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E65E0709F5\u0022", + "name": "cou", + "description": "updated", + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E65CDCE69A\u0022", + "name": "create", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E65D4FE2D0\u0022", + "name": "get", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E65D7BA75A\u0022", + "name": "list", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + }, + { + "@odata.etag": "\u00220x8D9E1E65D9D0D1D\u0022", + "name": "list2", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources(\u0027cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "7a1ea5ab-7fc2-11ec-b486-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "402", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:58 GMT", + "elapsed-time": "7", + "ETag": "W/\u00220x8D9E1E65E0709F5\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "7a1ea5ab-7fc2-11ec-b486-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E65E0709F5\u0022", + "name": "cou", + "description": "updated", + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "227", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "7a31388a-7fc2-11ec-841f-74c63bed1137" + }, + "RequestBody": { + "name": "couunch", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "401", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:58 GMT", + "elapsed-time": "36", + "ETag": "W/\u00220x8D9E1E65E46C8BA\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027couunch\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "7a31388a-7fc2-11ec-841f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E65E46C8BA\u0022", + "name": "couunch", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources(\u0027couunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "253", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "7a48641a-7fc2-11ec-a239-74c63bed1137" + }, + "RequestBody": { + "name": "couunch", + "description": "updated", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "406", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:58 GMT", + "elapsed-time": "30", + "ETag": "W/\u00220x8D9E1E65E63E95D\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "7a48641a-7fc2-11ec-a239-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E65E63E95D\u0022", + "name": "couunch", + "description": "updated", + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources(\u0027couunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "293", + "Content-Type": "application/json", + "If-Match": "\u00220x8D9E1E65E46C8BA\u0022", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "7a65978b-7fc2-11ec-bdb6-74c63bed1137" + }, + "RequestBody": { + "name": "couunch", + "description": "changed", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + }, + "@odata.etag": "\u00220x8D9E1E65E46C8BA\u0022" + }, + "StatusCode": 412, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "160", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:58 GMT", + "elapsed-time": "8", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "7a65978b-7fc2-11ec-bdb6-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "The precondition given in one of the request headers evaluated to false. No change was made to the resource from this request." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "227", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "7a7fe682-7fc2-11ec-842d-74c63bed1137" + }, + "RequestBody": { + "name": "delunch", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "401", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:58 GMT", + "elapsed-time": "35", + "ETag": "W/\u00220x8D9E1E65E94B632\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027delunch\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "7a7fe682-7fc2-11ec-842d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E65E94B632\u0022", + "name": "delunch", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources(\u0027delunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "253", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "7a963395-7fc2-11ec-a441-74c63bed1137" + }, + "RequestBody": { + "name": "delunch", + "description": "updated", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "406", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:58 GMT", + "elapsed-time": "31", + "ETag": "W/\u00220x8D9E1E65EAB6F28\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "7a963395-7fc2-11ec-a441-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E65EAB6F28\u0022", + "name": "delunch", + "description": "updated", + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources(\u0027delunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "If-Match": "\u00220x8D9E1E65E94B632\u0022", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "7aad4164-7fc2-11ec-85a7-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 412, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "160", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:59 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "7aad4164-7fc2-11ec-85a7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "The precondition given in one of the request headers evaluated to false. No change was made to the resource from this request." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "230", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "7ac0683f-7fc2-11ec-b0c2-74c63bed1137" + }, + "RequestBody": { + "name": "delstrunch", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "404", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:59 GMT", + "elapsed-time": "38", + "ETag": "W/\u00220x8D9E1E65ED781BD\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027delstrunch\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "7ac0683f-7fc2-11ec-b0c2-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E65ED781BD\u0022", + "name": "delstrunch", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources(\u0027delstrunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "256", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "7ad8efee-7fc2-11ec-9acb-74c63bed1137" + }, + "RequestBody": { + "name": "delstrunch", + "description": "updated", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "searchcontainer" + } + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "409", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:59 GMT", + "elapsed-time": "51", + "ETag": "W/\u00220x8D9E1E65EEDECA6\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "7ad8efee-7fc2-11ec-9acb-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E65EEDECA6\u0022", + "name": "delstrunch", + "description": "updated", + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "searchcontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_create_datasource.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_create_datasource.yaml deleted file mode 100644 index b0f9ed380e4d..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_create_datasource.yaml +++ /dev/null @@ -1,54 +0,0 @@ -interactions: -- request: - body: '{"name": "sample-datasource", "type": "azureblob", "credentials": {"connectionString": - "DefaultEndpointsProtocol=https;AccountName=storagename;AccountKey=NzhL3hKZbJBuJ2484dPTR+xF30kYaWSSCbs2BzLgVVI1woqeST/1IgqaLm6QAOTxtGvxctSNbIR/1hW8yH+bJg==;EndpointSuffix=core.windows.net"}, - "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '319' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search54bc1a2e.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search54bc1a2e.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CA294A6E44A\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '407' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:12:58 GMT - elapsed-time: - - '211' - etag: - - W/"0x8D96CA294A6E44A" - expires: - - '-1' - location: - - https://search54bc1a2e.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - b15c28c1-0a7e-11ec-959a-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_create_or_update_datasource.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_create_or_update_datasource.yaml deleted file mode 100644 index 96f1741316e4..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_create_or_update_datasource.yaml +++ /dev/null @@ -1,242 +0,0 @@ -interactions: -- request: - body: '{"name": "sample-datasource", "type": "azureblob", "credentials": {"connectionString": - "DefaultEndpointsProtocol=https;AccountName=storagename;AccountKey=NzhL3hKZbJBuJ2484dPTR+xF30kYaWSSCbs2BzLgVVI1woqeST/1IgqaLm6QAOTxtGvxctSNbIR/1hW8yH+bJg==;EndpointSuffix=core.windows.net"}, - "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '319' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search715d1e50.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search715d1e50.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CA29DA678C5\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '407' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:13:13 GMT - elapsed-time: - - '347' - etag: - - W/"0x8D96CA29DA678C5" - expires: - - '-1' - location: - - https://search715d1e50.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - ba3cf4b7-0a7e-11ec-b330-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search715d1e50.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search715d1e50.search.windows.net/$metadata#datasources","value":[{"@odata.etag":"\"0x8D96CA29DA678C5\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '411' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:13:13 GMT - elapsed-time: - - '58' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - ba9a58f2-0a7e-11ec-9432-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"name": "sample-datasource", "description": "updated", "type": "azureblob", - "credentials": {"connectionString": "DefaultEndpointsProtocol=https;AccountName=storagename;AccountKey=NzhL3hKZbJBuJ2484dPTR+xF30kYaWSSCbs2BzLgVVI1woqeST/1IgqaLm6QAOTxtGvxctSNbIR/1hW8yH+bJg==;EndpointSuffix=core.windows.net"}, - "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '345' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://search715d1e50.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search715d1e50.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CA29DC43F60\"","name":"sample-datasource","description":"updated","type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '412' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:13:13 GMT - elapsed-time: - - '50' - etag: - - W/"0x8D96CA29DC43F60" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - baaa2f0c-0a7e-11ec-87f4-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search715d1e50.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search715d1e50.search.windows.net/$metadata#datasources","value":[{"@odata.etag":"\"0x8D96CA29DC43F60\"","name":"sample-datasource","description":"updated","type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '416' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:13:13 GMT - elapsed-time: - - '15' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - bab92c51-0a7e-11ec-8858-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search715d1e50.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search715d1e50.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CA29DC43F60\"","name":"sample-datasource","description":"updated","type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '412' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:13:13 GMT - elapsed-time: - - '20' - etag: - - W/"0x8D96CA29DC43F60" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - bac225bf-0a7e-11ec-8834-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_create_or_update_datasource_if_unchanged.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_create_or_update_datasource_if_unchanged.yaml deleted file mode 100644 index dae5c4c46575..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_create_or_update_datasource_if_unchanged.yaml +++ /dev/null @@ -1,164 +0,0 @@ -interactions: -- request: - body: '{"name": "sample-datasource", "type": "azureblob", "credentials": {"connectionString": - "DefaultEndpointsProtocol=https;AccountName=storagename;AccountKey=NzhL3hKZbJBuJ2484dPTR+xF30kYaWSSCbs2BzLgVVI1woqeST/1IgqaLm6QAOTxtGvxctSNbIR/1hW8yH+bJg==;EndpointSuffix=core.windows.net"}, - "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '319' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search2014238a.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search2014238a.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CA2B3845418\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '407' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:13:50 GMT - elapsed-time: - - '129' - etag: - - W/"0x8D96CA2B3845418" - expires: - - '-1' - location: - - https://search2014238a.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - d04b2216-0a7e-11ec-8bf3-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "sample-datasource", "description": "updated", "type": "azureblob", - "credentials": {"connectionString": "DefaultEndpointsProtocol=https;AccountName=storagename;AccountKey=NzhL3hKZbJBuJ2484dPTR+xF30kYaWSSCbs2BzLgVVI1woqeST/1IgqaLm6QAOTxtGvxctSNbIR/1hW8yH+bJg==;EndpointSuffix=core.windows.net"}, - "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '345' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://search2014238a.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search2014238a.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CA2B395471F\"","name":"sample-datasource","description":"updated","type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '412' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:13:50 GMT - elapsed-time: - - '46' - etag: - - W/"0x8D96CA2B395471F" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - d07a25ef-0a7e-11ec-9aa8-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"name": "sample-datasource", "description": "changed", "type": "azureblob", - "credentials": {"connectionString": "DefaultEndpointsProtocol=https;AccountName=storagename;AccountKey=NzhL3hKZbJBuJ2484dPTR+xF30kYaWSSCbs2BzLgVVI1woqeST/1IgqaLm6QAOTxtGvxctSNbIR/1hW8yH+bJg==;EndpointSuffix=core.windows.net"}, - "container": {"name": "searchcontainer"}, "@odata.etag": "\"0x8D96CA2B3845418\""}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '385' - Content-Type: - - application/json - If-Match: - - '"0x8D96CA2B3845418"' - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://search2014238a.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - response: - body: - string: '{"error":{"code":"","message":"The precondition given in one of the - request headers evaluated to false. No change was made to the resource from - this request."}}' - headers: - cache-control: - - no-cache - content-language: - - en - content-length: - - '160' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:13:50 GMT - elapsed-time: - - '8' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - d0886b00-0a7e-11ec-8488-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 412 - message: Precondition Failed -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_delete_datasource.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_delete_datasource.yaml deleted file mode 100644 index 7555499ac395..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_delete_datasource.yaml +++ /dev/null @@ -1,178 +0,0 @@ -interactions: -- request: - body: '{"name": "sample-datasource", "type": "azureblob", "credentials": {"connectionString": - "DefaultEndpointsProtocol=https;AccountName=storagename;AccountKey=NzhL3hKZbJBuJ2484dPTR+xF30kYaWSSCbs2BzLgVVI1woqeST/1IgqaLm6QAOTxtGvxctSNbIR/1hW8yH+bJg==;EndpointSuffix=core.windows.net"}, - "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '319' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search549e1a2d.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search549e1a2d.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CA2BC5A871B\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '407' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:14:05 GMT - elapsed-time: - - '50' - etag: - - W/"0x8D96CA2BC5A871B" - expires: - - '-1' - location: - - https://search549e1a2d.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - d91ebf13-0a7e-11ec-85c8-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search549e1a2d.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search549e1a2d.search.windows.net/$metadata#datasources","value":[{"@odata.etag":"\"0x8D96CA2BC5A871B\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '411' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:14:05 GMT - elapsed-time: - - '45' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - d94f920a-0a7e-11ec-8dec-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '0' - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: DELETE - uri: https://search549e1a2d.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - date: - - Tue, 31 Aug 2021 17:14:05 GMT - elapsed-time: - - '25' - expires: - - '-1' - pragma: - - no-cache - request-id: - - d95de0dc-0a7e-11ec-b53e-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 204 - message: No Content -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search549e1a2d.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search549e1a2d.search.windows.net/$metadata#datasources","value":[]}' - headers: - cache-control: - - no-cache - content-length: - - '95' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:14:05 GMT - elapsed-time: - - '7' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - d96872ce-0a7e-11ec-8a06-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_delete_datasource_if_unchanged.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_delete_datasource_if_unchanged.yaml deleted file mode 100644 index 696b5733d76b..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_delete_datasource_if_unchanged.yaml +++ /dev/null @@ -1,158 +0,0 @@ -interactions: -- request: - body: '{"name": "sample-datasource", "type": "azureblob", "credentials": {"connectionString": - "DefaultEndpointsProtocol=https;AccountName=storagename;AccountKey=NzhL3hKZbJBuJ2484dPTR+xF30kYaWSSCbs2BzLgVVI1woqeST/1IgqaLm6QAOTxtGvxctSNbIR/1hW8yH+bJg==;EndpointSuffix=core.windows.net"}, - "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '319' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchcd7f1f67.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchcd7f1f67.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CA2C4DA9B2B\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '407' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:14:18 GMT - elapsed-time: - - '53' - etag: - - W/"0x8D96CA2C4DA9B2B" - expires: - - '-1' - location: - - https://searchcd7f1f67.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - e1abd2a4-0a7e-11ec-bd18-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "sample-datasource", "description": "updated", "type": "azureblob", - "credentials": {"connectionString": "DefaultEndpointsProtocol=https;AccountName=storagename;AccountKey=NzhL3hKZbJBuJ2484dPTR+xF30kYaWSSCbs2BzLgVVI1woqeST/1IgqaLm6QAOTxtGvxctSNbIR/1hW8yH+bJg==;EndpointSuffix=core.windows.net"}, - "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '345' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://searchcd7f1f67.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchcd7f1f67.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CA2C4E88067\"","name":"sample-datasource","description":"updated","type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '412' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:14:18 GMT - elapsed-time: - - '29' - etag: - - W/"0x8D96CA2C4E88067" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - e1cfd3d8-0a7e-11ec-897b-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '0' - If-Match: - - '"0x8D96CA2C4DA9B2B"' - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: DELETE - uri: https://searchcd7f1f67.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - response: - body: - string: '{"error":{"code":"","message":"The precondition given in one of the - request headers evaluated to false. No change was made to the resource from - this request."}}' - headers: - cache-control: - - no-cache - content-language: - - en - content-length: - - '160' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:14:18 GMT - elapsed-time: - - '9' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - e1dbcc0d-0a7e-11ec-9945-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 412 - message: Precondition Failed -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_delete_datasource_string_if_unchanged.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_delete_datasource_string_if_unchanged.yaml deleted file mode 100644 index 1777440fcf94..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_delete_datasource_string_if_unchanged.yaml +++ /dev/null @@ -1,108 +0,0 @@ -interactions: -- request: - body: '{"name": "sample-datasource", "type": "azureblob", "credentials": {"connectionString": - "DefaultEndpointsProtocol=https;AccountName=storagename;AccountKey=NzhL3hKZbJBuJ2484dPTR+xF30kYaWSSCbs2BzLgVVI1woqeST/1IgqaLm6QAOTxtGvxctSNbIR/1hW8yH+bJg==;EndpointSuffix=core.windows.net"}, - "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '319' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchb71c225d.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchb71c225d.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CA2CDA5CFED\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '407' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:14:33 GMT - elapsed-time: - - '49' - etag: - - W/"0x8D96CA2CDA5CFED" - expires: - - '-1' - location: - - https://searchb71c225d.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - ea67426a-0a7e-11ec-beba-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "sample-datasource", "description": "updated", "type": "azureblob", - "credentials": {"connectionString": "DefaultEndpointsProtocol=https;AccountName=storagename;AccountKey=NzhL3hKZbJBuJ2484dPTR+xF30kYaWSSCbs2BzLgVVI1woqeST/1IgqaLm6QAOTxtGvxctSNbIR/1hW8yH+bJg==;EndpointSuffix=core.windows.net"}, - "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '345' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://searchb71c225d.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchb71c225d.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CA2CDB2A388\"","name":"sample-datasource","description":"updated","type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '412' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:14:33 GMT - elapsed-time: - - '37' - etag: - - W/"0x8D96CA2CDB2A388" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - ea99709b-0a7e-11ec-92f4-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_get_datasource.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_get_datasource.yaml deleted file mode 100644 index 6b68f9c0e8c1..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_get_datasource.yaml +++ /dev/null @@ -1,100 +0,0 @@ -interactions: -- request: - body: '{"name": "sample-datasource", "type": "azureblob", "credentials": {"connectionString": - "DefaultEndpointsProtocol=https;AccountName=storagename;AccountKey=NzhL3hKZbJBuJ2484dPTR+xF30kYaWSSCbs2BzLgVVI1woqeST/1IgqaLm6QAOTxtGvxctSNbIR/1hW8yH+bJg==;EndpointSuffix=core.windows.net"}, - "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '319' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search7d318fa.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search7d318fa.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CA2D645F4FD\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '406' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:14:48 GMT - elapsed-time: - - '50' - etag: - - W/"0x8D96CA2D645F4FD" - expires: - - '-1' - location: - - https://search7d318fa.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - f3177e17-0a7e-11ec-ba64-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search7d318fa.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search7d318fa.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CA2D645F4FD\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '406' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:14:48 GMT - elapsed-time: - - '18' - etag: - - W/"0x8D96CA2D645F4FD" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - f33a77f9-0a7e-11ec-890a-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_list_datasource.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_list_datasource.yaml deleted file mode 100644 index 480b5a881d24..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_data_source_live.test_list_datasource.yaml +++ /dev/null @@ -1,150 +0,0 @@ -interactions: -- request: - body: '{"name": "sample-datasource", "type": "azureblob", "credentials": {"connectionString": - "DefaultEndpointsProtocol=https;AccountName=storagename;AccountKey=NzhL3hKZbJBuJ2484dPTR+xF30kYaWSSCbs2BzLgVVI1woqeST/1IgqaLm6QAOTxtGvxctSNbIR/1hW8yH+bJg==;EndpointSuffix=core.windows.net"}, - "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '319' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search22291976.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search22291976.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CA2DEAAB3E8\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '407' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:15:02 GMT - elapsed-time: - - '33' - etag: - - W/"0x8D96CA2DEAAB3E8" - expires: - - '-1' - location: - - https://search22291976.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - fb7dc01f-0a7e-11ec-b1a9-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "another-sample", "type": "azureblob", "credentials": {"connectionString": - "DefaultEndpointsProtocol=https;AccountName=storagename;AccountKey=NzhL3hKZbJBuJ2484dPTR+xF30kYaWSSCbs2BzLgVVI1woqeST/1IgqaLm6QAOTxtGvxctSNbIR/1hW8yH+bJg==;EndpointSuffix=core.windows.net"}, - "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '316' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search22291976.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search22291976.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CA2DEB6C406\"","name":"another-sample","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '404' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:15:02 GMT - elapsed-time: - - '32' - etag: - - W/"0x8D96CA2DEB6C406" - expires: - - '-1' - location: - - https://search22291976.search.windows.net/datasources('another-sample')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - fb9e6ba2-0a7e-11ec-bc10-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search22291976.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search22291976.search.windows.net/$metadata#datasources","value":[{"@odata.etag":"\"0x8D96CA2DEB6C406\"","name":"another-sample","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null},{"@odata.etag":"\"0x8D96CA2DEAAB3E8\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '725' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:15:02 GMT - elapsed-time: - - '24' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - fbaa5d61-0a7e-11ec-b9ee-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.pyTestSearchIndexClienttest_search_index_client.json b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.pyTestSearchIndexClienttest_search_index_client.json new file mode 100644 index 000000000000..110718695de8 --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.pyTestSearchIndexClienttest_search_index_client.json @@ -0,0 +1,1697 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/servicestats?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "687dd46e-7fc2-11ec-8b52-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "590", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:29 GMT", + "elapsed-time": "24", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "687dd46e-7fc2-11ec-8b52-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#Microsoft.Azure.Search.V2021_04_30_Preview.ServiceStatistics", + "counters": { + "documentCount": { + "usage": 0, + "quota": null + }, + "indexesCount": { + "usage": 0, + "quota": 50 + }, + "indexersCount": { + "usage": 0, + "quota": 50 + }, + "dataSourcesCount": { + "usage": 0, + "quota": 50 + }, + "storageSize": { + "usage": 0, + "quota": 26843545600 + }, + "synonymMaps": { + "usage": 0, + "quota": 5 + }, + "skillsetCount": { + "usage": 0, + "quota": 50 + } + }, + "limits": { + "maxFieldsPerIndex": 3000, + "maxFieldNestingDepthPerIndex": 10, + "maxComplexCollectionFieldsPerIndex": 40, + "maxComplexObjectsInCollectionsPerDocument": 3000 + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "68e9405d-7fc2-11ec-8c17-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "95", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:29 GMT", + "elapsed-time": "21", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "68e9405d-7fc2-11ec-8c17-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes", + "value": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "457", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "68ffec31-7fc2-11ec-bc25-74c63bed1137" + }, + "RequestBody": { + "name": "hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false, + "filterable": false, + "sortable": false, + "facetable": false + }, + { + "name": "baseRate", + "type": "Edm.Double", + "key": false, + "retrievable": true, + "searchable": false, + "filterable": false, + "sortable": false, + "facetable": false + } + ], + "scoringProfiles": [ + { + "name": "MyProfile" + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "1040", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:29 GMT", + "elapsed-time": "515", + "ETag": "W/\u00220x8D9E1E64D5E1021\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "68ffec31-7fc2-11ec-bc25-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E64D5E1021\u0022", + "name": "hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [ + { + "name": "MyProfile", + "functionAggregation": null, + "text": null, + "functions": [] + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "69603917-7fc2-11ec-a403-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1044", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:29 GMT", + "elapsed-time": "35", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "69603917-7fc2-11ec-a403-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E64D5E1021\u0022", + "name": "hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [ + { + "name": "MyProfile", + "functionAggregation": null, + "text": null, + "functions": [] + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "697652ee-7fc2-11ec-9d07-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1040", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:30 GMT", + "elapsed-time": "16", + "ETag": "W/\u00220x8D9E1E64D5E1021\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "697652ee-7fc2-11ec-9d07-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E64D5E1021\u0022", + "name": "hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [ + { + "name": "MyProfile", + "functionAggregation": null, + "text": null, + "functions": [] + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels\u0027)/search.stats?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6989f4dc-7fc2-11ec-a538-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "169", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:30 GMT", + "elapsed-time": "15", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6989f4dc-7fc2-11ec-a538-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#Microsoft.Azure.Search.V2021_04_30_Preview.IndexStatistics", + "documentCount": 0, + "storageSize": 0 + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "316", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "699ef1b1-7fc2-11ec-a4e5-74c63bed1137" + }, + "RequestBody": { + "name": "hotels-del-unchanged", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + }, + { + "name": "baseRate", + "type": "Edm.Double", + "retrievable": true + } + ], + "scoringProfiles": [ + { + "name": "MyProfile" + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "1048", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:30 GMT", + "elapsed-time": "609", + "ETag": "W/\u00220x8D9E1E64E0C10DC\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-del-unchanged\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "699ef1b1-7fc2-11ec-a4e5-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E64E0C10DC\u0022", + "name": "hotels-del-unchanged", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [ + { + "name": "MyProfile", + "functionAggregation": null, + "text": null, + "functions": [] + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-del-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "295", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6a0e0e3e-7fc2-11ec-a1eb-74c63bed1137" + }, + "RequestBody": { + "name": "hotels-del-unchanged", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + }, + { + "name": "baseRate", + "type": "Edm.Double", + "retrievable": true + } + ], + "scoringProfiles": [], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + } + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "974", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:32 GMT", + "elapsed-time": "124", + "ETag": "W/\u00220x8D9E1E64E30AA7F\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6a0e0e3e-7fc2-11ec-a1eb-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E64E30AA7F\u0022", + "name": "hotels-del-unchanged", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-del-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "If-Match": "\u00220x8D9E1E64E0C10DC\u0022", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6a34030f-7fc2-11ec-a16d-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 412, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "160", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:32 GMT", + "elapsed-time": "38", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6a34030f-7fc2-11ec-a16d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "The precondition given in one of the request headers evaluated to false. No change was made to the resource from this request." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "440", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6a4b857c-7fc2-11ec-bcf6-74c63bed1137" + }, + "RequestBody": { + "name": "hotels-cou", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false, + "filterable": false, + "sortable": false, + "facetable": false + }, + { + "name": "baseRate", + "type": "Edm.Double", + "key": false, + "retrievable": true, + "searchable": false, + "filterable": false, + "sortable": false, + "facetable": false + } + ], + "scoringProfiles": [], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "970", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:32 GMT", + "elapsed-time": "619", + "ETag": "W/\u00220x8D9E1E64EB9C387\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-cou\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6a4b857c-7fc2-11ec-bcf6-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E64EB9C387\u0022", + "name": "hotels-cou", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "461", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6abbf91d-7fc2-11ec-9c4c-74c63bed1137" + }, + "RequestBody": { + "name": "hotels-cou", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false, + "filterable": false, + "sortable": false, + "facetable": false + }, + { + "name": "baseRate", + "type": "Edm.Double", + "key": false, + "retrievable": true, + "searchable": false, + "filterable": false, + "sortable": false, + "facetable": false + } + ], + "scoringProfiles": [ + { + "name": "MyProfile" + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + } + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1044", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:33 GMT", + "elapsed-time": "115", + "ETag": "W/\u00220x8D9E1E64EDDC0F0\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6abbf91d-7fc2-11ec-9c4c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E64EDDC0F0\u0022", + "name": "hotels-cou", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [ + { + "name": "MyProfile", + "functionAggregation": null, + "text": null, + "functions": [] + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "316", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6adf888b-7fc2-11ec-9956-74c63bed1137" + }, + "RequestBody": { + "name": "hotels-coa-unchanged", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + }, + { + "name": "baseRate", + "type": "Edm.Double", + "retrievable": true + } + ], + "scoringProfiles": [ + { + "name": "MyProfile" + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "1048", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:33 GMT", + "elapsed-time": "567", + "ETag": "W/\u00220x8D9E1E64F459B43\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-coa-unchanged\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6adf888b-7fc2-11ec-9956-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E64F459B43\u0022", + "name": "hotels-coa-unchanged", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [ + { + "name": "MyProfile", + "functionAggregation": null, + "text": null, + "functions": [] + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-coa-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "295", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6b479dfb-7fc2-11ec-821d-74c63bed1137" + }, + "RequestBody": { + "name": "hotels-coa-unchanged", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + }, + { + "name": "baseRate", + "type": "Edm.Double", + "retrievable": true + } + ], + "scoringProfiles": [], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + } + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "974", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:33 GMT", + "elapsed-time": "112", + "ETag": "W/\u00220x8D9E1E64F688771\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6b479dfb-7fc2-11ec-821d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E64F688771\u0022", + "name": "hotels-coa-unchanged", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-coa-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "335", + "Content-Type": "application/json", + "If-Match": "\u00220x8D9E1E64F459B43\u0022", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6b6b405d-7fc2-11ec-a8f4-74c63bed1137" + }, + "RequestBody": { + "name": "hotels-coa-unchanged", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + }, + { + "name": "baseRate", + "type": "Edm.Double", + "retrievable": true + } + ], + "scoringProfiles": [], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "@odata.etag": "\u00220x8D9E1E64F459B43\u0022" + }, + "StatusCode": 412, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "160", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:34 GMT", + "elapsed-time": "18", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6b6b405d-7fc2-11ec-a8f4-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "The precondition given in one of the request headers evaluated to false. No change was made to the resource from this request." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels\u0027)/search.analyze?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "55", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6b808421-7fc2-11ec-a4e2-74c63bed1137" + }, + "RequestBody": { + "text": "One\u0027s \u003Ctwo/\u003E", + "analyzer": "standard.lucene" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "265", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:34 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6b808421-7fc2-11ec-a4e2-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#Microsoft.Azure.Search.V2021_04_30_Preview.AnalyzeResult", + "tokens": [ + { + "token": "one\u0027s", + "startOffset": 0, + "endOffset": 5, + "position": 0 + }, + { + "token": "two", + "startOffset": 7, + "endOffset": 10, + "position": 1 + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6b931b9a-7fc2-11ec-a827-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "3766", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:42:34 GMT", + "elapsed-time": "104", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "6b931b9a-7fc2-11ec-a827-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E64F688771\u0022", + "name": "hotels-coa-unchanged", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + }, + { + "@odata.etag": "\u00220x8D9E1E64EDDC0F0\u0022", + "name": "hotels-cou", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [ + { + "name": "MyProfile", + "functionAggregation": null, + "text": null, + "functions": [] + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + }, + { + "@odata.etag": "\u00220x8D9E1E64E30AA7F\u0022", + "name": "hotels-del-unchanged", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + }, + { + "@odata.etag": "\u00220x8D9E1E64D5E1021\u0022", + "name": "hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + }, + { + "name": "baseRate", + "type": "Edm.Double", + "searchable": false, + "filterable": false, + "retrievable": true, + "sortable": false, + "facetable": false, + "key": false, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [ + { + "name": "MyProfile", + "functionAggregation": null, + "text": null, + "functions": [] + } + ], + "corsOptions": { + "allowedOrigins": [ + "*" + ], + "maxAgeInSeconds": 60 + }, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-coa-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6bbef710-7fc2-11ec-9bc7-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:42:34 GMT", + "elapsed-time": "137", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "6bbef710-7fc2-11ec-9bc7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6be44b1d-7fc2-11ec-a84c-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:42:34 GMT", + "elapsed-time": "138", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "6be44b1d-7fc2-11ec-a84c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels-del-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6c0a25d8-7fc2-11ec-a452-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:42:35 GMT", + "elapsed-time": "137", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "6c0a25d8-7fc2-11ec-a452-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes(\u0027hotels\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "6c302d4c-7fc2-11ec-b67f-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:42:35 GMT", + "elapsed-time": "339", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "6c302d4c-7fc2-11ec-b67f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_analyze_text.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_analyze_text.yaml deleted file mode 100644 index c592052b4fde..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_analyze_text.yaml +++ /dev/null @@ -1,50 +0,0 @@ -interactions: -- request: - body: '{"text": "One''s ", "analyzer": "standard.lucene"}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '55' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchcf75135f.search.windows.net/indexes('drgqefsg')/search.analyze?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchcf75135f.search.windows.net/$metadata#Microsoft.Azure.Search.V2021_04_30_Preview.AnalyzeResult","tokens":[{"token":"one''s","startOffset":0,"endOffset":5,"position":0},{"token":"two","startOffset":7,"endOffset":10,"position":1}]}' - headers: - cache-control: - - no-cache - content-length: - - '261' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:15:17 GMT - elapsed-time: - - '51' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 044aceb0-0a7f-11ec-a683-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_create_index.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_create_index.yaml deleted file mode 100644 index 2d9f569a9d3d..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_create_index.yaml +++ /dev/null @@ -1,57 +0,0 @@ -interactions: -- request: - body: '{"name": "hotels", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false, "filterable": false, - "sortable": false, "facetable": false}, {"name": "baseRate", "type": "Edm.Double", - "key": false, "retrievable": true, "searchable": false, "filterable": false, - "sortable": false, "facetable": false}], "scoringProfiles": [{"name": "MyProfile"}], - "corsOptions": {"allowedOrigins": ["*"], "maxAgeInSeconds": 60}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '457' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchce941332.search.windows.net/indexes?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchce941332.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CA2F04738C4\"","name":"hotels","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"baseRate","type":"Edm.Double","searchable":false,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}],"scoringProfiles":[{"name":"MyProfile","functionAggregation":null,"text":null,"functions":[]}],"corsOptions":{"allowedOrigins":["*"],"maxAgeInSeconds":60},"suggesters":[],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '1020' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:15:32 GMT - elapsed-time: - - '956' - etag: - - W/"0x8D96CA2F04738C4" - expires: - - '-1' - location: - - https://searchce941332.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 0c8e39de-0a7f-11ec-835f-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_create_or_update_index.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_create_or_update_index.yaml deleted file mode 100644 index af7a0570ea20..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_create_or_update_index.yaml +++ /dev/null @@ -1,116 +0,0 @@ -interactions: -- request: - body: '{"name": "hotels", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false, "filterable": false, - "sortable": false, "facetable": false}, {"name": "baseRate", "type": "Edm.Double", - "key": false, "retrievable": true, "searchable": false, "filterable": false, - "sortable": false, "facetable": false}], "scoringProfiles": [], "corsOptions": - {"allowedOrigins": ["*"], "maxAgeInSeconds": 60}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '436' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://searcha5711754.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searcha5711754.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CA2F9BBC46A\"","name":"hotels","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"baseRate","type":"Edm.Double","searchable":false,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}],"scoringProfiles":[],"corsOptions":{"allowedOrigins":["*"],"maxAgeInSeconds":60},"suggesters":[],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '946' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:15:48 GMT - elapsed-time: - - '913' - etag: - - W/"0x8D96CA2F9BBC46A" - expires: - - '-1' - location: - - https://searcha5711754.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 15fc7f51-0a7f-11ec-a6b6-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "hotels", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false, "filterable": false, - "sortable": false, "facetable": false}, {"name": "baseRate", "type": "Edm.Double", - "key": false, "retrievable": true, "searchable": false, "filterable": false, - "sortable": false, "facetable": false}], "scoringProfiles": [{"name": "MyProfile"}], - "corsOptions": {"allowedOrigins": ["*"], "maxAgeInSeconds": 60}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '457' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://searcha5711754.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searcha5711754.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CA2F9F33236\"","name":"hotels","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"baseRate","type":"Edm.Double","searchable":false,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}],"scoringProfiles":[{"name":"MyProfile","functionAggregation":null,"text":null,"functions":[]}],"corsOptions":{"allowedOrigins":["*"],"maxAgeInSeconds":60},"suggesters":[],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '1020' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:15:48 GMT - elapsed-time: - - '313' - etag: - - W/"0x8D96CA2F9F33236" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 16b0fd17-0a7f-11ec-8e3c-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_create_or_update_indexes_if_unchanged.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_create_or_update_indexes_if_unchanged.yaml deleted file mode 100644 index 060205b2b3d3..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_create_or_update_indexes_if_unchanged.yaml +++ /dev/null @@ -1,167 +0,0 @@ -interactions: -- request: - body: '{"name": "hotels", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false}, {"name": "baseRate", - "type": "Edm.Double", "retrievable": true}], "scoringProfiles": [{"name": "MyProfile"}], - "corsOptions": {"allowedOrigins": ["*"], "maxAgeInSeconds": 60}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '302' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search34391d66.search.windows.net/indexes?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search34391d66.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CA3034BA57E\"","name":"hotels","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"baseRate","type":"Edm.Double","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}],"scoringProfiles":[{"name":"MyProfile","functionAggregation":null,"text":null,"functions":[]}],"corsOptions":{"allowedOrigins":["*"],"maxAgeInSeconds":60},"suggesters":[],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '1014' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:16:04 GMT - elapsed-time: - - '705' - etag: - - W/"0x8D96CA3034BA57E" - expires: - - '-1' - location: - - https://search34391d66.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 1fba676e-0a7f-11ec-b6a6-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "hotels", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false}, {"name": "baseRate", - "type": "Edm.Double", "retrievable": true}], "scoringProfiles": [], "corsOptions": - {"allowedOrigins": ["*"], "maxAgeInSeconds": 60}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '281' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://search34391d66.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search34391d66.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CA30372203B\"","name":"hotels","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"baseRate","type":"Edm.Double","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}],"scoringProfiles":[],"corsOptions":{"allowedOrigins":["*"],"maxAgeInSeconds":60},"suggesters":[],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '940' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:16:04 GMT - elapsed-time: - - '196' - etag: - - W/"0x8D96CA30372203B" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 20404645-0a7f-11ec-9fc0-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"name": "hotels", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false}, {"name": "baseRate", - "type": "Edm.Double", "retrievable": true}], "scoringProfiles": [], "corsOptions": - {"allowedOrigins": ["*"], "maxAgeInSeconds": 60}, "@odata.etag": "\"0x8D96CA3034BA57E\""}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '321' - Content-Type: - - application/json - If-Match: - - '"0x8D96CA3034BA57E"' - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://search34391d66.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - response: - body: - string: '{"error":{"code":"","message":"The precondition given in one of the - request headers evaluated to false. No change was made to the resource from - this request."}}' - headers: - cache-control: - - no-cache - content-language: - - en - content-length: - - '160' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:16:04 GMT - elapsed-time: - - '29' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 206623f9-0a7f-11ec-aa7f-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 412 - message: Precondition Failed -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_delete_indexes.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_delete_indexes.yaml deleted file mode 100644 index bd3d7c218ec7..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_delete_indexes.yaml +++ /dev/null @@ -1,82 +0,0 @@ -interactions: -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '0' - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: DELETE - uri: https://searchf61a1409.search.windows.net/indexes('drgqefsg')?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - date: - - Tue, 31 Aug 2021 17:16:18 GMT - elapsed-time: - - '186' - expires: - - '-1' - pragma: - - no-cache - request-id: - - 28ad8b63-0a7f-11ec-8129-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 204 - message: No Content -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchf61a1409.search.windows.net/indexes?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchf61a1409.search.windows.net/$metadata#indexes","value":[]}' - headers: - cache-control: - - no-cache - content-length: - - '91' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:16:23 GMT - elapsed-time: - - '96' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 2bde4ea3-0a7f-11ec-8269-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_delete_indexes_if_unchanged.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_delete_indexes_if_unchanged.yaml deleted file mode 100644 index 7bcbcf911a3b..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_delete_indexes_if_unchanged.yaml +++ /dev/null @@ -1,160 +0,0 @@ -interactions: -- request: - body: '{"name": "hotels", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false}, {"name": "baseRate", - "type": "Edm.Double", "retrievable": true}], "scoringProfiles": [{"name": "MyProfile"}], - "corsOptions": {"allowedOrigins": ["*"], "maxAgeInSeconds": 60}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '302' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search1f361943.search.windows.net/indexes?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search1f361943.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CA317E070F6\"","name":"hotels","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"baseRate","type":"Edm.Double","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}],"scoringProfiles":[{"name":"MyProfile","functionAggregation":null,"text":null,"functions":[]}],"corsOptions":{"allowedOrigins":["*"],"maxAgeInSeconds":60},"suggesters":[],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '1014' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:16:38 GMT - elapsed-time: - - '732' - etag: - - W/"0x8D96CA317E070F6" - expires: - - '-1' - location: - - https://search1f361943.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 3440b7f9-0a7f-11ec-b52c-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "hotels", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false}, {"name": "baseRate", - "type": "Edm.Double", "retrievable": true}], "scoringProfiles": [], "corsOptions": - {"allowedOrigins": ["*"], "maxAgeInSeconds": 60}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '281' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://search1f361943.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search1f361943.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CA318053DCA\"","name":"hotels","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"baseRate","type":"Edm.Double","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}],"scoringProfiles":[],"corsOptions":{"allowedOrigins":["*"],"maxAgeInSeconds":60},"suggesters":[],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '940' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:16:38 GMT - elapsed-time: - - '191' - etag: - - W/"0x8D96CA318053DCA" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 34d4a85a-0a7f-11ec-a2d2-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '0' - If-Match: - - '"0x8D96CA317E070F6"' - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: DELETE - uri: https://search1f361943.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - response: - body: - string: '{"error":{"code":"","message":"The precondition given in one of the - request headers evaluated to false. No change was made to the resource from - this request."}}' - headers: - cache-control: - - no-cache - content-language: - - en - content-length: - - '160' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:16:38 GMT - elapsed-time: - - '16' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 34f9991b-0a7f-11ec-815c-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 412 - message: Precondition Failed -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_get_index.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_get_index.yaml deleted file mode 100644 index 9d0dce66ab7f..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_get_index.yaml +++ /dev/null @@ -1,48 +0,0 @@ -interactions: -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search966a11fe.search.windows.net/indexes('drgqefsg')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search966a11fe.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CA31E8BBDD4\"","name":"drgqefsg","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"hotelName","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"description","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"en.lucene","normalizer":null,"synonymMaps":[]},{"name":"descriptionFr","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"fr.lucene","normalizer":null,"synonymMaps":[]},{"name":"category","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"tags","type":"Collection(Edm.String)","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"parkingIncluded","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"smokingAllowed","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"lastRenovationDate","type":"Edm.DateTimeOffset","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"rating","type":"Edm.Int32","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"location","type":"Edm.GeographyPoint","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"address","type":"Edm.ComplexType","fields":[{"name":"streetAddress","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"city","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"stateProvince","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"country","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"postalCode","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}]},{"name":"rooms","type":"Collection(Edm.ComplexType)","fields":[{"name":"description","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"en.lucene","normalizer":null,"synonymMaps":[]},{"name":"descriptionFr","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"fr.lucene","normalizer":null,"synonymMaps":[]},{"name":"type","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"baseRate","type":"Edm.Double","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"bedOptions","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"sleepsCount","type":"Edm.Int32","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"smokingAllowed","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"tags","type":"Collection(Edm.String)","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}]}],"scoringProfiles":[{"name":"nearest","functionAggregation":"sum","text":null,"functions":[{"fieldName":"location","interpolation":"linear","type":"distance","boost":2.0,"freshness":null,"magnitude":null,"distance":{"referencePointParameter":"myloc","boostingDistance":100.0},"tag":null}]}],"corsOptions":null,"suggesters":[{"name":"sg","searchMode":"analyzingInfixMatching","sourceFields":["description","hotelName"]}],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '6676' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:16:53 GMT - elapsed-time: - - '21' - etag: - - W/"0x8D96CA31E8BBDD4" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 3dacd1a1-0a7f-11ec-a62f-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_get_index_statistics.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_get_index_statistics.yaml deleted file mode 100644 index ede31b7e5b9f..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_get_index_statistics.yaml +++ /dev/null @@ -1,46 +0,0 @@ -interactions: -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search783716a8.search.windows.net/indexes('drgqefsg')/search.stats?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search783716a8.search.windows.net/$metadata#Microsoft.Azure.Search.V2021_04_30_Preview.IndexStatistics","documentCount":0,"storageSize":0}' - headers: - cache-control: - - no-cache - content-length: - - '165' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:17:08 GMT - elapsed-time: - - '30' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 465b627d-0a7f-11ec-a11d-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_get_service_statistics.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_get_service_statistics.yaml deleted file mode 100644 index 51d1516349eb..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_get_service_statistics.yaml +++ /dev/null @@ -1,46 +0,0 @@ -interactions: -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searcha71e1781.search.windows.net/servicestats?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searcha71e1781.search.windows.net/$metadata#Microsoft.Azure.Search.V2021_04_30_Preview.ServiceStatistics","counters":{"documentCount":{"usage":0,"quota":null},"indexesCount":{"usage":0,"quota":3},"indexersCount":{"usage":0,"quota":3},"dataSourcesCount":{"usage":0,"quota":3},"storageSize":{"usage":0,"quota":52428800},"synonymMaps":{"usage":0,"quota":3},"skillsetCount":{"usage":0,"quota":3}},"limits":{"maxFieldsPerIndex":1000,"maxFieldNestingDepthPerIndex":10,"maxComplexCollectionFieldsPerIndex":40,"maxComplexObjectsInCollectionsPerDocument":3000}}' - headers: - cache-control: - - no-cache - content-length: - - '579' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:17:18 GMT - elapsed-time: - - '66' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 4cad5783-0a7f-11ec-b320-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_list_indexes.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_list_indexes.yaml deleted file mode 100644 index 8787aab3998b..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_list_indexes.yaml +++ /dev/null @@ -1,46 +0,0 @@ -interactions: -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchcf9c1352.search.windows.net/indexes?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchcf9c1352.search.windows.net/$metadata#indexes","value":[{"@odata.etag":"\"0x8D96CA3364DF38C\"","name":"drgqefsg","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"hotelName","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"description","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"en.lucene","normalizer":null,"synonymMaps":[]},{"name":"descriptionFr","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"fr.lucene","normalizer":null,"synonymMaps":[]},{"name":"category","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"tags","type":"Collection(Edm.String)","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"parkingIncluded","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"smokingAllowed","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"lastRenovationDate","type":"Edm.DateTimeOffset","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"rating","type":"Edm.Int32","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"location","type":"Edm.GeographyPoint","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"address","type":"Edm.ComplexType","fields":[{"name":"streetAddress","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"city","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"stateProvince","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"country","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"postalCode","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}]},{"name":"rooms","type":"Collection(Edm.ComplexType)","fields":[{"name":"description","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"en.lucene","normalizer":null,"synonymMaps":[]},{"name":"descriptionFr","type":"Edm.String","searchable":true,"filterable":false,"retrievable":true,"sortable":false,"facetable":false,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":"fr.lucene","normalizer":null,"synonymMaps":[]},{"name":"type","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"baseRate","type":"Edm.Double","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"bedOptions","type":"Edm.String","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"sleepsCount","type":"Edm.Int32","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"smokingAllowed","type":"Edm.Boolean","searchable":false,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]},{"name":"tags","type":"Collection(Edm.String)","searchable":true,"filterable":true,"retrievable":true,"sortable":false,"facetable":true,"key":false,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}]}],"scoringProfiles":[{"name":"nearest","functionAggregation":"sum","text":null,"functions":[{"fieldName":"location","interpolation":"linear","type":"distance","boost":2.0,"freshness":null,"magnitude":null,"distance":{"referencePointParameter":"myloc","boostingDistance":100.0},"tag":null}]}],"corsOptions":null,"suggesters":[{"name":"sg","searchMode":"analyzingInfixMatching","sourceFields":["description","hotelName"]}],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}]}' - headers: - cache-control: - - no-cache - content-length: - - '6680' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:17:32 GMT - elapsed-time: - - '73' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 55616a12-0a7f-11ec-89dc-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_list_indexes_empty.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_list_indexes_empty.yaml deleted file mode 100644 index a7d8f7f03d13..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_live.test_list_indexes_empty.yaml +++ /dev/null @@ -1,46 +0,0 @@ -interactions: -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search4c2f15e0.search.windows.net/indexes?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search4c2f15e0.search.windows.net/$metadata#indexes","value":[]}' - headers: - cache-control: - - no-cache - content-length: - - '91' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:17:43 GMT - elapsed-time: - - '30' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 5b3173ac-0a7f-11ec-a127-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.pyTestSearchSkillsettest_skillset_crud.json b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.pyTestSearchSkillsettest_skillset_crud.json new file mode 100644 index 000000000000..bdbcff1fbf47 --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.pyTestSearchSkillsettest_skillset_crud.json @@ -0,0 +1,1889 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "1348", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1a2109d1-7fc2-11ec-b40a-74c63bed1137" + }, + "RequestBody": { + "name": "test-ss-create", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "skill1", + "description": "Skill Version 1", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS1" + } + ], + "includeTypelessEntities": true + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityRecognitionSkill", + "name": "skill2", + "description": "Skill Version 3", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS2" + } + ], + "modelVersion": "3" + }, + { + "@odata.type": "#Microsoft.Skills.Text.SentimentSkill", + "name": "skill3", + "description": "Sentiment V1", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "score", + "targetName": "scoreS3" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.SentimentSkill", + "name": "skill4", + "description": "Sentiment V3", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "confidenceScores", + "targetName": "scoreS4" + } + ], + "includeOpinionMining": true + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityLinkingSkill", + "name": "skill5", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "entities", + "targetName": "entitiesS5" + } + ], + "minimumPrecision": 0.5 + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "1971", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:40:18 GMT", + "elapsed-time": "75", + "ETag": "W/\u00220x8D9E1E5FE8AEC9F\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "1a2109d1-7fc2-11ec-b40a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#skillsets/$entity", + "@odata.etag": "\u00220x8D9E1E5FE8AEC9F\u0022", + "name": "test-ss-create", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "skill1", + "description": "Skill Version 1", + "context": null, + "categories": [], + "defaultLanguageCode": null, + "minimumPrecision": null, + "includeTypelessEntities": true, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS1" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityRecognitionSkill", + "name": "skill2", + "description": "Skill Version 3", + "context": null, + "categories": [], + "defaultLanguageCode": null, + "minimumPrecision": null, + "modelVersion": "3", + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS2" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.SentimentSkill", + "name": "skill3", + "description": "Sentiment V1", + "context": null, + "defaultLanguageCode": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "score", + "targetName": "scoreS3" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.SentimentSkill", + "name": "skill4", + "description": "Sentiment V3", + "context": null, + "defaultLanguageCode": null, + "modelVersion": null, + "includeOpinionMining": true, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "confidenceScores", + "targetName": "scoreS4" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityLinkingSkill", + "name": "skill5", + "description": null, + "context": null, + "defaultLanguageCode": null, + "minimumPrecision": 0.5, + "modelVersion": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "entities", + "targetName": "entitiesS5" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1a95e834-7fc2-11ec-8de5-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "2225", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:40:18 GMT", + "elapsed-time": "22", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "1a95e834-7fc2-11ec-8de5-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#skillsets", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E5FE8AEC9F\u0022", + "name": "test-ss-create", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "skill1", + "description": "Skill Version 1", + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": true, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS1" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityRecognitionSkill", + "name": "skill2", + "description": "Skill Version 3", + "context": "/document", + "categories": [ + "Product", + "PhoneNumber", + "Person", + "Quantity", + "Organization", + "IPAddress", + "URL", + "Email", + "Event", + "Skill", + "Location", + "PersonType", + "Address", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "modelVersion": "3", + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS2" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.SentimentSkill", + "name": "skill3", + "description": "Sentiment V1", + "context": "/document", + "defaultLanguageCode": "en", + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "score", + "targetName": "scoreS3" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.SentimentSkill", + "name": "skill4", + "description": "Sentiment V3", + "context": "/document", + "defaultLanguageCode": "en", + "modelVersion": null, + "includeOpinionMining": true, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "confidenceScores", + "targetName": "scoreS4" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityLinkingSkill", + "name": "skill5", + "description": null, + "context": "/document", + "defaultLanguageCode": "en", + "minimumPrecision": 0.5, + "modelVersion": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "entities", + "targetName": "entitiesS5" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create\u0027)/search.resetskills?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "66", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1aae8e1e-7fc2-11ec-a670-74c63bed1137" + }, + "RequestBody": { + "skillNames": [ + "skill1", + "skill2", + "skill3", + "skill4", + "skill5" + ] + }, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:40:18 GMT", + "elapsed-time": "21", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "1aae8e1e-7fc2-11ec-a670-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "256", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1ac3750a-7fc2-11ec-856b-74c63bed1137" + }, + "RequestBody": { + "name": "test-ss-get", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "616", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:40:18 GMT", + "elapsed-time": "38", + "ETag": "W/\u00220x8D9E1E5FED9763E\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-get\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "1ac3750a-7fc2-11ec-856b-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#skillsets/$entity", + "@odata.etag": "\u00220x8D9E1E5FED9763E\u0022", + "name": "test-ss-get", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": null, + "description": null, + "context": null, + "categories": [], + "defaultLanguageCode": null, + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-get\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1ada8728-7fc2-11ec-b482-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "693", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:40:18 GMT", + "elapsed-time": "13", + "ETag": "W/\u00220x8D9E1E5FED9763E\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "1ada8728-7fc2-11ec-b482-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#skillsets/$entity", + "@odata.etag": "\u00220x8D9E1E5FED9763E\u0022", + "name": "test-ss-get", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "#1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "260", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1aee2eec-7fc2-11ec-821f-74c63bed1137" + }, + "RequestBody": { + "name": "test-ss-list-1", + "description": "desc1", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "620", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:40:18 GMT", + "elapsed-time": "38", + "ETag": "W/\u00220x8D9E1E5FF03B458\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-list-1\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "1aee2eec-7fc2-11ec-821f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#skillsets/$entity", + "@odata.etag": "\u00220x8D9E1E5FF03B458\u0022", + "name": "test-ss-list-1", + "description": "desc1", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": null, + "description": null, + "context": null, + "categories": [], + "defaultLanguageCode": null, + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "260", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1b04e261-7fc2-11ec-9c76-74c63bed1137" + }, + "RequestBody": { + "name": "test-ss-list-2", + "description": "desc2", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "620", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:40:18 GMT", + "elapsed-time": "38", + "ETag": "W/\u00220x8D9E1E5FF1A4649\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-list-2\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "1b04e261-7fc2-11ec-9c76-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#skillsets/$entity", + "@odata.etag": "\u00220x8D9E1E5FF1A4649\u0022", + "name": "test-ss-list-2", + "description": "desc2", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": null, + "description": null, + "context": null, + "categories": [], + "defaultLanguageCode": null, + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1b1b193f-7fc2-11ec-895f-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "4036", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:40:19 GMT", + "elapsed-time": "25", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "1b1b193f-7fc2-11ec-895f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#skillsets", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E5FE8AEC9F\u0022", + "name": "test-ss-create", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "skill1", + "description": "Skill Version 1", + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": true, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS1" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityRecognitionSkill", + "name": "skill2", + "description": "Skill Version 3", + "context": "/document", + "categories": [ + "Product", + "PhoneNumber", + "Person", + "Quantity", + "Organization", + "IPAddress", + "URL", + "Email", + "Event", + "Skill", + "Location", + "PersonType", + "Address", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "modelVersion": "3", + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS2" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.SentimentSkill", + "name": "skill3", + "description": "Sentiment V1", + "context": "/document", + "defaultLanguageCode": "en", + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "score", + "targetName": "scoreS3" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.SentimentSkill", + "name": "skill4", + "description": "Sentiment V3", + "context": "/document", + "defaultLanguageCode": "en", + "modelVersion": null, + "includeOpinionMining": true, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "confidenceScores", + "targetName": "scoreS4" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityLinkingSkill", + "name": "skill5", + "description": null, + "context": "/document", + "defaultLanguageCode": "en", + "minimumPrecision": 0.5, + "modelVersion": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "entities", + "targetName": "entitiesS5" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5FED9763E\u0022", + "name": "test-ss-get", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "#1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5FF03B458\u0022", + "name": "test-ss-list-1", + "description": "desc1", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "#1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5FF1A4649\u0022", + "name": "test-ss-list-2", + "description": "desc2", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "#1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create-or-update-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "280", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1b30e92e-7fc2-11ec-8b23-74c63bed1137" + }, + "RequestBody": { + "name": "test-ss-create-or-update-unchanged", + "description": "desc1", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "640", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:40:19 GMT", + "elapsed-time": "42", + "ETag": "W/\u00220x8D9E1E5FF467FEE\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create-or-update-unchanged\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "1b30e92e-7fc2-11ec-8b23-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#skillsets/$entity", + "@odata.etag": "\u00220x8D9E1E5FF467FEE\u0022", + "name": "test-ss-create-or-update-unchanged", + "description": "desc1", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": null, + "description": null, + "context": null, + "categories": [], + "defaultLanguageCode": null, + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create-or-update-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "320", + "Content-Type": "application/json", + "If-Match": "\u00220x8D9E1E5FF467FEE\u0022", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1b485fd7-7fc2-11ec-b831-74c63bed1137" + }, + "RequestBody": { + "name": "test-ss-create-or-update-unchanged", + "description": "desc2", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "@odata.etag": "\u00220x8D9E1E5FF467FEE\u0022" + }, + "StatusCode": 500, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "56", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:40:19 GMT", + "elapsed-time": "15", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "1b485fd7-7fc2-11ec-b831-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "An error has occurred." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create-or-update-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "320", + "Content-Type": "application/json", + "If-Match": "\u00220x8D9E1E5FF467FEE\u0022", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1b485fd7-7fc2-11ec-b831-74c63bed1137" + }, + "RequestBody": { + "name": "test-ss-create-or-update-unchanged", + "description": "desc2", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "@odata.etag": "\u00220x8D9E1E5FF467FEE\u0022" + }, + "StatusCode": 500, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "56", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:40:19 GMT", + "elapsed-time": "20", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "1b485fd7-7fc2-11ec-b831-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "An error has occurred." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create-or-update-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "320", + "Content-Type": "application/json", + "If-Match": "\u00220x8D9E1E5FF467FEE\u0022", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1b485fd7-7fc2-11ec-b831-74c63bed1137" + }, + "RequestBody": { + "name": "test-ss-create-or-update-unchanged", + "description": "desc2", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "@odata.etag": "\u00220x8D9E1E5FF467FEE\u0022" + }, + "StatusCode": 500, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "56", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:40:21 GMT", + "elapsed-time": "41", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "1b485fd7-7fc2-11ec-b831-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "An error has occurred." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create-or-update-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "320", + "Content-Type": "application/json", + "If-Match": "\u00220x8D9E1E5FF467FEE\u0022", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1b485fd7-7fc2-11ec-b831-74c63bed1137" + }, + "RequestBody": { + "name": "test-ss-create-or-update-unchanged", + "description": "desc2", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "inputs": [ + { + "name": "text", + "source": "/document/content" + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "@odata.etag": "\u00220x8D9E1E5FF467FEE\u0022" + }, + "StatusCode": 500, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "56", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:40:25 GMT", + "elapsed-time": "18", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "1b485fd7-7fc2-11ec-b831-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "An error has occurred." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1ea81da7-7fc2-11ec-bf9d-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "4661", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:40:25 GMT", + "elapsed-time": "88", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "1ea81da7-7fc2-11ec-bf9d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#skillsets", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E5FF467FEE\u0022", + "name": "test-ss-create-or-update-unchanged", + "description": "desc1", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "#1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5FE8AEC9F\u0022", + "name": "test-ss-create", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "skill1", + "description": "Skill Version 1", + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": true, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS1" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityRecognitionSkill", + "name": "skill2", + "description": "Skill Version 3", + "context": "/document", + "categories": [ + "Product", + "PhoneNumber", + "Person", + "Quantity", + "Organization", + "IPAddress", + "URL", + "Email", + "Event", + "Skill", + "Location", + "PersonType", + "Address", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "modelVersion": "3", + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizationsS2" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.SentimentSkill", + "name": "skill3", + "description": "Sentiment V1", + "context": "/document", + "defaultLanguageCode": "en", + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "score", + "targetName": "scoreS3" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.SentimentSkill", + "name": "skill4", + "description": "Sentiment V3", + "context": "/document", + "defaultLanguageCode": "en", + "modelVersion": null, + "includeOpinionMining": true, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "confidenceScores", + "targetName": "scoreS4" + } + ] + }, + { + "@odata.type": "#Microsoft.Skills.Text.V3.EntityLinkingSkill", + "name": "skill5", + "description": null, + "context": "/document", + "defaultLanguageCode": "en", + "minimumPrecision": 0.5, + "modelVersion": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "entities", + "targetName": "entitiesS5" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5FED9763E\u0022", + "name": "test-ss-get", + "description": "desc", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "#1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5FF03B458\u0022", + "name": "test-ss-list-1", + "description": "desc1", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "#1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5FF1A4649\u0022", + "name": "test-ss-list-2", + "description": "desc2", + "skills": [ + { + "@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", + "name": "#1", + "description": null, + "context": "/document", + "categories": [ + "Person", + "Quantity", + "Organization", + "URL", + "Email", + "Location", + "DateTime" + ], + "defaultLanguageCode": "en", + "minimumPrecision": null, + "includeTypelessEntities": null, + "inputs": [ + { + "name": "text", + "source": "/document/content", + "sourceContext": null, + "inputs": [] + } + ], + "outputs": [ + { + "name": "organizations", + "targetName": "organizations" + } + ] + } + ], + "cognitiveServices": null, + "knowledgeStore": null, + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create-or-update-unchanged\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1ec7af81-7fc2-11ec-ab6f-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:40:25 GMT", + "elapsed-time": "28", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "1ec7af81-7fc2-11ec-ab6f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-create\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1f070653-7fc2-11ec-8a1a-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:40:25 GMT", + "elapsed-time": "32", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "1f070653-7fc2-11ec-8a1a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-get\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1f1dce03-7fc2-11ec-85e3-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:40:25 GMT", + "elapsed-time": "26", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "1f1dce03-7fc2-11ec-85e3-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-list-1\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1f320808-7fc2-11ec-9ad4-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:40:26 GMT", + "elapsed-time": "28", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "1f320808-7fc2-11ec-9ad4-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/skillsets(\u0027test-ss-list-2\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "1f47376c-7fc2-11ec-a0c1-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:40:26 GMT", + "elapsed-time": "235", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "1f47376c-7fc2-11ec-a0c1-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_create_or_update_skillset.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_create_or_update_skillset.yaml deleted file mode 100644 index f3fc2646770f..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_create_or_update_skillset.yaml +++ /dev/null @@ -1,202 +0,0 @@ -interactions: -- request: - body: '{"name": "test-ss", "description": "desc1", "skills": [{"@odata.type": - "#Microsoft.Skills.Text.EntityRecognitionSkill", "inputs": [{"name": "text", - "source": "/document/content"}], "outputs": [{"name": "organizations", "targetName": - "organizations"}]}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '253' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://searche2bf1c71.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searche2bf1c71.search.windows.net/$metadata#skillsets/$entity","@odata.etag":"\"0x8D977BF242A141A\"","name":"test-ss","description":"desc1","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":null,"description":null,"context":null,"categories":[],"defaultLanguageCode":null,"minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '609' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 20:35:07 GMT - elapsed-time: - - '2124' - etag: - - W/"0x8D977BF242A141A" - expires: - - '-1' - location: - - https://searche2bf1c71.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 3ff59952-159b-11ec-bda5-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "test-ss", "description": "desc2", "skills": [{"@odata.type": - "#Microsoft.Skills.Text.EntityRecognitionSkill", "inputs": [{"name": "text", - "source": "/document/content"}], "outputs": [{"name": "organizations", "targetName": - "organizations"}]}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '253' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://searche2bf1c71.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searche2bf1c71.search.windows.net/$metadata#skillsets/$entity","@odata.etag":"\"0x8D977BF243E8A49\"","name":"test-ss","description":"desc2","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":null,"description":null,"context":null,"categories":[],"defaultLanguageCode":null,"minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '609' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 20:35:07 GMT - elapsed-time: - - '85' - etag: - - W/"0x8D977BF243E8A49" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 41558274-159b-11ec-bc0f-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searche2bf1c71.search.windows.net/skillsets?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searche2bf1c71.search.windows.net/$metadata#skillsets","value":[{"@odata.etag":"\"0x8D977BF243E8A49\"","name":"test-ss","description":"desc2","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":"#1","description":null,"context":"/document","categories":["Person","Quantity","Organization","URL","Email","Location","DateTime"],"defaultLanguageCode":"en","minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '690' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 20:35:07 GMT - elapsed-time: - - '69' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 4169c877-159b-11ec-9f5a-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searche2bf1c71.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searche2bf1c71.search.windows.net/$metadata#skillsets/$entity","@odata.etag":"\"0x8D977BF243E8A49\"","name":"test-ss","description":"desc2","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":"#1","description":null,"context":"/document","categories":["Person","Quantity","Organization","URL","Email","Location","DateTime"],"defaultLanguageCode":"en","minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '686' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 20:35:07 GMT - elapsed-time: - - '15' - etag: - - W/"0x8D977BF243E8A49" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 417b5016-159b-11ec-acf0-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_create_or_update_skillset_if_unchanged.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_create_or_update_skillset_if_unchanged.yaml deleted file mode 100644 index 7f3fecf24c0b..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_create_or_update_skillset_if_unchanged.yaml +++ /dev/null @@ -1,156 +0,0 @@ -interactions: -- request: - body: '{"name": "test-ss", "description": "desc1", "skills": [{"@odata.type": - "#Microsoft.Skills.Text.EntityRecognitionSkill", "inputs": [{"name": "text", - "source": "/document/content"}], "outputs": [{"name": "organizations", "targetName": - "organizations"}]}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '253' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://search792321ab.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search792321ab.search.windows.net/$metadata#skillsets/$entity","@odata.etag":"\"0x8D977CB70C7008A\"","name":"test-ss","description":"desc1","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":null,"description":null,"context":null,"categories":[],"defaultLanguageCode":null,"minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '609' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 22:03:10 GMT - elapsed-time: - - '2131' - etag: - - W/"0x8D977CB70C7008A" - expires: - - '-1' - location: - - https://search792321ab.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 8ca7995e-15a7-11ec-aa34-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "test-ss", "description": "desc2", "skills": [{"@odata.type": - "#Microsoft.Skills.Text.EntityRecognitionSkill", "inputs": [{"name": "text", - "source": "/document/content"}], "outputs": [{"name": "organizations", "targetName": - "organizations"}]}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '253' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://search792321ab.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search792321ab.search.windows.net/$metadata#skillsets/$entity","@odata.etag":"\"0x8D977CB70D7F380\"","name":"test-ss","description":"desc2","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":null,"description":null,"context":null,"categories":[],"defaultLanguageCode":null,"minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '609' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 22:03:10 GMT - elapsed-time: - - '61' - etag: - - W/"0x8D977CB70D7F380" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 8e04f88a-15a7-11ec-8243-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search792321ab.search.windows.net/skillsets?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search792321ab.search.windows.net/$metadata#skillsets","value":[{"@odata.etag":"\"0x8D977CB70D7F380\"","name":"test-ss","description":"desc2","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":"#1","description":null,"context":"/document","categories":["Person","Quantity","Organization","URL","Email","Location","DateTime"],"defaultLanguageCode":"en","minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '690' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 22:03:10 GMT - elapsed-time: - - '75' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 8e159a1f-15a7-11ec-bf98-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_create_or_update_skillset_inplace.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_create_or_update_skillset_inplace.yaml deleted file mode 100644 index 1fd4894cba5c..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_create_or_update_skillset_inplace.yaml +++ /dev/null @@ -1,202 +0,0 @@ -interactions: -- request: - body: '{"name": "test-ss", "description": "desc1", "skills": [{"@odata.type": - "#Microsoft.Skills.Text.EntityRecognitionSkill", "inputs": [{"name": "text", - "source": "/document/content"}], "outputs": [{"name": "organizations", "targetName": - "organizations"}]}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '253' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://searchd4ef1fac.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchd4ef1fac.search.windows.net/$metadata#skillsets/$entity","@odata.etag":"\"0x8D977C87A42B270\"","name":"test-ss","description":"desc1","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":null,"description":null,"context":null,"categories":[],"defaultLanguageCode":null,"minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '609' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 21:41:57 GMT - elapsed-time: - - '1916' - etag: - - W/"0x8D977C87A42B270" - expires: - - '-1' - location: - - https://searchd4ef1fac.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 963d1c9d-15a4-11ec-9672-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "test-ss", "description": "desc2", "skills": [{"@odata.type": - "#Microsoft.Skills.Text.EntityRecognitionSkill", "inputs": [{"name": "text", - "source": "/document/content"}], "outputs": [{"name": "organizations", "targetName": - "organizations"}]}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '253' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://searchd4ef1fac.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchd4ef1fac.search.windows.net/$metadata#skillsets/$entity","@odata.etag":"\"0x8D977C87A5B209B\"","name":"test-ss","description":"desc2","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":null,"description":null,"context":null,"categories":[],"defaultLanguageCode":null,"minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '609' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 21:41:57 GMT - elapsed-time: - - '79' - etag: - - W/"0x8D977C87A5B209B" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 977f2425-15a4-11ec-ac05-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchd4ef1fac.search.windows.net/skillsets?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchd4ef1fac.search.windows.net/$metadata#skillsets","value":[{"@odata.etag":"\"0x8D977C87A5B209B\"","name":"test-ss","description":"desc2","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":"#1","description":null,"context":"/document","categories":["Person","Quantity","Organization","URL","Email","Location","DateTime"],"defaultLanguageCode":"en","minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '690' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 21:41:57 GMT - elapsed-time: - - '67' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 97945ba1-15a4-11ec-95bc-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchd4ef1fac.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchd4ef1fac.search.windows.net/$metadata#skillsets/$entity","@odata.etag":"\"0x8D977C87A5B209B\"","name":"test-ss","description":"desc2","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":"#1","description":null,"context":"/document","categories":["Person","Quantity","Organization","URL","Email","Location","DateTime"],"defaultLanguageCode":"en","minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '686' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 21:41:57 GMT - elapsed-time: - - '14' - etag: - - W/"0x8D977C87A5B209B" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 97a7b2a7-15a4-11ec-aed2-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_create_skillset.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_create_skillset.yaml deleted file mode 100644 index 9e9d0439ce64..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_create_skillset.yaml +++ /dev/null @@ -1,157 +0,0 @@ -interactions: -- request: - body: '{"name": "test-ss", "description": "desc", "skills": [{"@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", - "name": "skill1", "description": "Skill Version 1", "inputs": [{"name": "text", - "source": "/document/content"}], "outputs": [{"name": "organizations", "targetName": - "organizationsS1"}], "includeTypelessEntities": true}, {"@odata.type": "#Microsoft.Skills.Text.V3.EntityRecognitionSkill", - "name": "skill2", "description": "Skill Version 3", "inputs": [{"name": "text", - "source": "/document/content"}], "outputs": [{"name": "organizations", "targetName": - "organizationsS2"}], "modelVersion": "3"}, {"@odata.type": "#Microsoft.Skills.Text.SentimentSkill", - "name": "skill3", "description": "Sentiment V1", "inputs": [{"name": "text", - "source": "/document/content"}], "outputs": [{"name": "score", "targetName": - "scoreS3"}]}, {"@odata.type": "#Microsoft.Skills.Text.V3.SentimentSkill", "name": - "skill4", "description": "Sentiment V3", "inputs": [{"name": "text", "source": - "/document/content"}], "outputs": [{"name": "confidenceScores", "targetName": - "scoreS4"}], "includeOpinionMining": true}, {"@odata.type": "#Microsoft.Skills.Text.V3.EntityLinkingSkill", - "name": "skill5", "inputs": [{"name": "text", "source": "/document/content"}], - "outputs": [{"name": "entities", "targetName": "entitiesS5"}], "minimumPrecision": - 0.5}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '1341' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b5 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchd998184f.search.windows.net/skillsets?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchd998184f.search.windows.net/$metadata#skillsets/$entity","@odata.etag":"\"0x8D99B03895900E6\"","name":"test-ss","description":"desc","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":"skill1","description":"Skill - Version 1","context":null,"categories":[],"defaultLanguageCode":null,"minimumPrecision":null,"includeTypelessEntities":true,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizationsS1"}]},{"@odata.type":"#Microsoft.Skills.Text.V3.EntityRecognitionSkill","name":"skill2","description":"Skill - Version 3","context":null,"categories":[],"defaultLanguageCode":null,"minimumPrecision":null,"modelVersion":"3","inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizationsS2"}]},{"@odata.type":"#Microsoft.Skills.Text.SentimentSkill","name":"skill3","description":"Sentiment - V1","context":null,"defaultLanguageCode":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"score","targetName":"scoreS3"}]},{"@odata.type":"#Microsoft.Skills.Text.V3.SentimentSkill","name":"skill4","description":"Sentiment - V3","context":null,"defaultLanguageCode":null,"modelVersion":null,"includeOpinionMining":true,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"confidenceScores","targetName":"scoreS4"}]},{"@odata.type":"#Microsoft.Skills.Text.V3.EntityLinkingSkill","name":"skill5","description":null,"context":null,"defaultLanguageCode":null,"minimumPrecision":0.5,"modelVersion":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"entities","targetName":"entitiesS5"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '1960' - content-type: - - application/json; odata.metadata=minimal - date: - - Fri, 29 Oct 2021 17:42:54 GMT - elapsed-time: - - '2093' - etag: - - W/"0x8D99B03895900E6" - expires: - - '-1' - location: - - https://searchd998184f.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - a4e19c2b-38df-11ec-9ba5-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b5 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchd998184f.search.windows.net/skillsets?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchd998184f.search.windows.net/$metadata#skillsets","value":[{"@odata.etag":"\"0x8D99B03895900E6\"","name":"test-ss","description":"desc","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":"skill1","description":"Skill - Version 1","context":"/document","categories":["Person","Quantity","Organization","URL","Email","Location","DateTime"],"defaultLanguageCode":"en","minimumPrecision":null,"includeTypelessEntities":true,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizationsS1"}]},{"@odata.type":"#Microsoft.Skills.Text.V3.EntityRecognitionSkill","name":"skill2","description":"Skill - Version 3","context":"/document","categories":["Product","PhoneNumber","Person","Quantity","Organization","IPAddress","URL","Email","Event","Skill","Location","PersonType","Address","DateTime"],"defaultLanguageCode":"en","minimumPrecision":null,"modelVersion":"3","inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizationsS2"}]},{"@odata.type":"#Microsoft.Skills.Text.SentimentSkill","name":"skill3","description":"Sentiment - V1","context":"/document","defaultLanguageCode":"en","inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"score","targetName":"scoreS3"}]},{"@odata.type":"#Microsoft.Skills.Text.V3.SentimentSkill","name":"skill4","description":"Sentiment - V3","context":"/document","defaultLanguageCode":"en","modelVersion":null,"includeOpinionMining":true,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"confidenceScores","targetName":"scoreS4"}]},{"@odata.type":"#Microsoft.Skills.Text.V3.EntityLinkingSkill","name":"skill5","description":null,"context":"/document","defaultLanguageCode":"en","minimumPrecision":0.5,"modelVersion":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"entities","targetName":"entitiesS5"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '2214' - content-type: - - application/json; odata.metadata=minimal - date: - - Fri, 29 Oct 2021 17:42:54 GMT - elapsed-time: - - '100' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - a65031ef-38df-11ec-ab76-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"skillNames": ["skill1", "skill2", "skill3", "skill4", "skill5"]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '66' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b5 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchd998184f.search.windows.net/skillsets('test-ss')/search.resetskills?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - date: - - Fri, 29 Oct 2021 17:42:54 GMT - elapsed-time: - - '47' - expires: - - '-1' - pragma: - - no-cache - request-id: - - a66c4a6c-38df-11ec-ae2d-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 204 - message: No Content -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_delete_skillset.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_delete_skillset.yaml deleted file mode 100644 index 6014d767b83b..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_delete_skillset.yaml +++ /dev/null @@ -1,178 +0,0 @@ -interactions: -- request: - body: '{"name": "test-ss", "description": "desc", "skills": [{"@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", - "inputs": [{"name": "text", "source": "/document/content"}], "outputs": [{"name": - "organizations", "targetName": "organizations"}]}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '252' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchd97c184e.search.windows.net/skillsets?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchd97c184e.search.windows.net/$metadata#skillsets/$entity","@odata.etag":"\"0x8D977C15538E247\"","name":"test-ss","description":"desc","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":null,"description":null,"context":null,"categories":[],"defaultLanguageCode":null,"minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '608' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 20:50:49 GMT - elapsed-time: - - '2250' - etag: - - W/"0x8D977C15538E247" - expires: - - '-1' - location: - - https://searchd97c184e.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 70f8e527-159d-11ec-8600-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchd97c184e.search.windows.net/skillsets?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchd97c184e.search.windows.net/$metadata#skillsets","value":[{"@odata.etag":"\"0x8D977C15538E247\"","name":"test-ss","description":"desc","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":"#1","description":null,"context":"/document","categories":["Person","Quantity","Organization","URL","Email","Location","DateTime"],"defaultLanguageCode":"en","minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '689' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 20:50:49 GMT - elapsed-time: - - '92' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 72684c35-159d-11ec-9149-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '0' - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: DELETE - uri: https://searchd97c184e.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - date: - - Tue, 14 Sep 2021 20:50:49 GMT - elapsed-time: - - '40' - expires: - - '-1' - pragma: - - no-cache - request-id: - - 727d7ca6-159d-11ec-9b97-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 204 - message: No Content -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchd97c184e.search.windows.net/skillsets?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchd97c184e.search.windows.net/$metadata#skillsets","value":[]}' - headers: - cache-control: - - no-cache - content-length: - - '93' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 20:50:49 GMT - elapsed-time: - - '9' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 728a490a-159d-11ec-bc59-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_delete_skillset_if_unchanged.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_delete_skillset_if_unchanged.yaml deleted file mode 100644 index 86f1bf8de282..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_delete_skillset_if_unchanged.yaml +++ /dev/null @@ -1,159 +0,0 @@ -interactions: -- request: - body: '{"name": "test-ss", "description": "desc", "skills": [{"@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", - "inputs": [{"name": "text", "source": "/document/content"}], "outputs": [{"name": - "organizations", "targetName": "organizations"}]}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '252' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search3a191d88.search.windows.net/skillsets?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search3a191d88.search.windows.net/$metadata#skillsets/$entity","@odata.etag":"\"0x8D977C34C46233E\"","name":"test-ss","description":"desc","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":null,"description":null,"context":null,"categories":[],"defaultLanguageCode":null,"minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '608' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 21:04:53 GMT - elapsed-time: - - '2226' - etag: - - W/"0x8D977C34C46233E" - expires: - - '-1' - location: - - https://search3a191d88.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 680ad3a0-159f-11ec-9d34-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "test-ss", "description": "updated", "skills": [{"@odata.type": - "#Microsoft.Skills.Text.EntityRecognitionSkill", "inputs": [{"name": "text", - "source": "/document/content"}], "outputs": [{"name": "organizations", "targetName": - "organizations"}]}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '255' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://search3a191d88.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search3a191d88.search.windows.net/$metadata#skillsets/$entity","@odata.etag":"\"0x8D977C34C593993\"","name":"test-ss","description":"updated","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":null,"description":null,"context":null,"categories":[],"defaultLanguageCode":null,"minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '611' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 21:04:53 GMT - elapsed-time: - - '68' - etag: - - W/"0x8D977C34C593993" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 69782ec6-159f-11ec-ab05-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '0' - If-Match: - - '"0x8D977C34C46233E"' - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: DELETE - uri: https://search3a191d88.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - response: - body: - string: '{"error":{"code":"","message":"The precondition given in one of the - request headers evaluated to false. No change was made to the resource from - this request."}}' - headers: - cache-control: - - no-cache - content-language: - - en - content-length: - - '160' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 21:04:53 GMT - elapsed-time: - - '20' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 698a3438-159f-11ec-8044-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 412 - message: Precondition Failed -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_get_skillset.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_get_skillset.yaml deleted file mode 100644 index 71191fd5bb71..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_get_skillset.yaml +++ /dev/null @@ -1,144 +0,0 @@ -interactions: -- request: - body: '{"name": "test-ss", "description": "desc", "skills": [{"@odata.type": "#Microsoft.Skills.Text.EntityRecognitionSkill", - "inputs": [{"name": "text", "source": "/document/content"}], "outputs": [{"name": - "organizations", "targetName": "organizations"}]}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '252' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search9274171b.search.windows.net/skillsets?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search9274171b.search.windows.net/$metadata#skillsets/$entity","@odata.etag":"\"0x8D977C3591A39FF\"","name":"test-ss","description":"desc","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":null,"description":null,"context":null,"categories":[],"defaultLanguageCode":null,"minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '608' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 21:05:14 GMT - elapsed-time: - - '2058' - etag: - - W/"0x8D977C3591A39FF" - expires: - - '-1' - location: - - https://search9274171b.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 74f3cf64-159f-11ec-886a-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search9274171b.search.windows.net/skillsets?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search9274171b.search.windows.net/$metadata#skillsets","value":[{"@odata.etag":"\"0x8D977C3591A39FF\"","name":"test-ss","description":"desc","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":"#1","description":null,"context":"/document","categories":["Person","Quantity","Organization","URL","Email","Location","DateTime"],"defaultLanguageCode":"en","minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '689' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 21:05:14 GMT - elapsed-time: - - '82' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 764ad3c7-159f-11ec-84fe-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search9274171b.search.windows.net/skillsets('test-ss')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search9274171b.search.windows.net/$metadata#skillsets/$entity","@odata.etag":"\"0x8D977C3591A39FF\"","name":"test-ss","description":"desc","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":"#1","description":null,"context":"/document","categories":["Person","Quantity","Organization","URL","Email","Location","DateTime"],"defaultLanguageCode":"en","minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '685' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 21:05:14 GMT - elapsed-time: - - '17' - etag: - - W/"0x8D977C3591A39FF" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 765f5d84-159f-11ec-be78-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_get_skillsets.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_get_skillsets.yaml deleted file mode 100644 index 38903fbd94fc..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_skillset_live.test_get_skillsets.yaml +++ /dev/null @@ -1,152 +0,0 @@ -interactions: -- request: - body: '{"name": "test-ss-1", "description": "desc1", "skills": [{"@odata.type": - "#Microsoft.Skills.Text.EntityRecognitionSkill", "inputs": [{"name": "text", - "source": "/document/content"}], "outputs": [{"name": "organizations", "targetName": - "organizations"}]}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '255' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchaa02178e.search.windows.net/skillsets?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchaa02178e.search.windows.net/$metadata#skillsets/$entity","@odata.etag":"\"0x8D977C3656261D4\"","name":"test-ss-1","description":"desc1","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":null,"description":null,"context":null,"categories":[],"defaultLanguageCode":null,"minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '611' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 21:05:35 GMT - elapsed-time: - - '2127' - etag: - - W/"0x8D977C3656261D4" - expires: - - '-1' - location: - - https://searchaa02178e.search.windows.net/skillsets('test-ss-1')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 8133f1db-159f-11ec-9110-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "test-ss-2", "description": "desc2", "skills": [{"@odata.type": - "#Microsoft.Skills.Text.EntityRecognitionSkill", "inputs": [{"name": "text", - "source": "/document/content"}], "outputs": [{"name": "organizations", "targetName": - "organizations"}]}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '255' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchaa02178e.search.windows.net/skillsets?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchaa02178e.search.windows.net/$metadata#skillsets/$entity","@odata.etag":"\"0x8D977C365713281\"","name":"test-ss-2","description":"desc2","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":null,"description":null,"context":null,"categories":[],"defaultLanguageCode":null,"minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '611' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 21:05:35 GMT - elapsed-time: - - '50' - etag: - - W/"0x8D977C365713281" - expires: - - '-1' - location: - - https://searchaa02178e.search.windows.net/skillsets('test-ss-2')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 829337aa-159f-11ec-9b0e-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b4 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchaa02178e.search.windows.net/skillsets?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchaa02178e.search.windows.net/$metadata#skillsets","value":[{"@odata.etag":"\"0x8D977C3656261D4\"","name":"test-ss-1","description":"desc1","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":"#1","description":null,"context":"/document","categories":["Person","Quantity","Organization","URL","Email","Location","DateTime"],"defaultLanguageCode":"en","minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null},{"@odata.etag":"\"0x8D977C365713281\"","name":"test-ss-2","description":"desc2","skills":[{"@odata.type":"#Microsoft.Skills.Text.EntityRecognitionSkill","name":"#1","description":null,"context":"/document","categories":["Person","Quantity","Organization","URL","Email","Location","DateTime"],"defaultLanguageCode":"en","minimumPrecision":null,"includeTypelessEntities":null,"inputs":[{"name":"text","source":"/document/content","sourceContext":null,"inputs":[]}],"outputs":[{"name":"organizations","targetName":"organizations"}]}],"cognitiveServices":null,"knowledgeStore":null,"encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '1292' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 14 Sep 2021 21:05:35 GMT - elapsed-time: - - '95' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 82a27edc-159f-11ec-9983-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.pyTestSearchClientSynonymMapstest_synonym_map.json b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.pyTestSearchClientSynonymMapstest_synonym_map.json new file mode 100644 index 000000000000..21559554e7a6 --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.pyTestSearchClientSynonymMapstest_synonym_map.json @@ -0,0 +1,1039 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0a052605-7fc2-11ec-bee8-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "99", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:51 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0a052605-7fc2-11ec-bee8-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "128", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0a6de1f3-7fc2-11ec-a85d-74c63bed1137" + }, + "RequestBody": { + "name": "synmap-create", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA" + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "277", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:51 GMT", + "elapsed-time": "22", + "ETag": "W/\u00220x8D9E1E5EE854772\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-create\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0a6de1f3-7fc2-11ec-a85d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E5EE854772\u0022", + "name": "synmap-create", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0a850cc7-7fc2-11ec-a0fe-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "281", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:51 GMT", + "elapsed-time": "12", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0a850cc7-7fc2-11ec-a0fe-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E5EE854772\u0022", + "name": "synmap-create", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-create\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0a9811d7-7fc2-11ec-9ab5-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:39:51 GMT", + "elapsed-time": "15", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "0a9811d7-7fc2-11ec-9ab5-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "125", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0aabfa2a-7fc2-11ec-a13c-74c63bed1137" + }, + "RequestBody": { + "name": "synmap-del", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA" + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "274", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:51 GMT", + "elapsed-time": "23", + "ETag": "W/\u00220x8D9E1E5EEC15D3A\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-del\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0aabfa2a-7fc2-11ec-a13c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E5EEC15D3A\u0022", + "name": "synmap-del", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0ac0cc5d-7fc2-11ec-9c19-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "278", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:51 GMT", + "elapsed-time": "11", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0ac0cc5d-7fc2-11ec-9c19-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E5EEC15D3A\u0022", + "name": "synmap-del", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-del\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0ad4505e-7fc2-11ec-bfd0-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:39:51 GMT", + "elapsed-time": "12", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "0ad4505e-7fc2-11ec-bfd0-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0ae7160a-7fc2-11ec-9645-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "99", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:51 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0ae7160a-7fc2-11ec-9645-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "129", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0af8e2fa-7fc2-11ec-a0b0-74c63bed1137" + }, + "RequestBody": { + "name": "synmap-delunch", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA" + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "278", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:52 GMT", + "elapsed-time": "32", + "ETag": "W/\u00220x8D9E1E5EF182300\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-delunch\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0af8e2fa-7fc2-11ec-a0b0-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E5EF182300\u0022", + "name": "synmap-delunch", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-delunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "127", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0b176e77-7fc2-11ec-a6b5-74c63bed1137" + }, + "RequestBody": { + "name": "synmap-delunch", + "format": "solr", + "synonyms": "W\na\ns\nh\ni\nn\ng\nt\no\nn\n,\n \nW\na\ns\nh\n.\n \n=\n\u003E\n \nW\nA" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "276", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:52 GMT", + "elapsed-time": "20", + "ETag": "W/\u00220x8D9E1E5EF32FA13\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0b176e77-7fc2-11ec-a6b5-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E5EF32FA13\u0022", + "name": "synmap-delunch", + "format": "solr", + "synonyms": "W\na\ns\nh\ni\nn\ng\nt\no\nn\n,\n \nW\na\ns\nh\n.\n \n=\n\u003E\n \nW\nA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-delunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "If-Match": "\u00220x8D9E1E5EF182300\u0022", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0b32b9ce-7fc2-11ec-8758-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 412, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "160", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:52 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0b32b9ce-7fc2-11ec-8758-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "The precondition given in one of the request headers evaluated to false. No change was made to the resource from this request." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-delunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0b47369b-7fc2-11ec-b1a0-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:39:52 GMT", + "elapsed-time": "15", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "0b47369b-7fc2-11ec-b1a0-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0b5acb0b-7fc2-11ec-870f-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "99", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:52 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0b5acb0b-7fc2-11ec-870f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "125", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0b6ca258-7fc2-11ec-b4d5-74c63bed1137" + }, + "RequestBody": { + "name": "synmap-get", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA" + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "274", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:52 GMT", + "elapsed-time": "33", + "ETag": "W/\u00220x8D9E1E5EF837F32\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-get\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0b6ca258-7fc2-11ec-b4d5-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E5EF837F32\u0022", + "name": "synmap-get", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0b834d9b-7fc2-11ec-a121-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "278", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:52 GMT", + "elapsed-time": "36", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0b834d9b-7fc2-11ec-a121-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E5EF837F32\u0022", + "name": "synmap-get", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-get\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0b9a51f8-7fc2-11ec-b8d8-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "274", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:52 GMT", + "elapsed-time": "6", + "ETag": "W/\u00220x8D9E1E5EF837F32\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0b9a51f8-7fc2-11ec-b8d8-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E5EF837F32\u0022", + "name": "synmap-get", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-get\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0bacbcc5-7fc2-11ec-a0b7-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:39:53 GMT", + "elapsed-time": "15", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "0bacbcc5-7fc2-11ec-a0b7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "127", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0bc0f35d-7fc2-11ec-b08c-74c63bed1137" + }, + "RequestBody": { + "name": "synmap-list1", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA" + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "276", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:53 GMT", + "elapsed-time": "22", + "ETag": "W/\u00220x8D9E1E5EFD6C310\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-list1\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0bc0f35d-7fc2-11ec-b08c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E5EFD6C310\u0022", + "name": "synmap-list1", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "81", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0bd64bfc-7fc2-11ec-a82f-74c63bed1137" + }, + "RequestBody": { + "name": "synmap-list2", + "format": "solr", + "synonyms": "Washington, Wash. =\u003E WA" + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "230", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:53 GMT", + "elapsed-time": "22", + "ETag": "W/\u00220x8D9E1E5EFEAE455\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-list2\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0bd64bfc-7fc2-11ec-a82f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E5EFEAE455\u0022", + "name": "synmap-list2", + "format": "solr", + "synonyms": "Washington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0bea8f88-7fc2-11ec-829c-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "416", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:53 GMT", + "elapsed-time": "50", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0bea8f88-7fc2-11ec-829c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E5EFD6C310\u0022", + "name": "synmap-list1", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5EFEAE455\u0022", + "name": "synmap-list2", + "format": "solr", + "synonyms": "Washington, Wash. =\u003E WA", + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-list1\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0c047305-7fc2-11ec-bb8c-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:39:53 GMT", + "elapsed-time": "12", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "0c047305-7fc2-11ec-bb8c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-list2\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0c183f61-7fc2-11ec-8716-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:39:53 GMT", + "elapsed-time": "12", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "0c183f61-7fc2-11ec-8716-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0c2ba127-7fc2-11ec-a071-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "99", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:53 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0c2ba127-7fc2-11ec-a071-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "125", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0c3e8672-7fc2-11ec-bdbc-74c63bed1137" + }, + "RequestBody": { + "name": "synmap-cou", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA" + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "274", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:54 GMT", + "elapsed-time": "23", + "ETag": "W/\u00220x8D9E1E5F05AD3BE\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-cou\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0c3e8672-7fc2-11ec-bdbc-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E5F05AD3BE\u0022", + "name": "synmap-cou", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0c5a9428-7fc2-11ec-9b49-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "278", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:54 GMT", + "elapsed-time": "32", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0c5a9428-7fc2-11ec-9b49-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E5F05AD3BE\u0022", + "name": "synmap-cou", + "format": "solr", + "synonyms": "USA, United States, United States of America\nWashington, Wash. =\u003E WA", + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "79", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0c71871d-7fc2-11ec-9740-74c63bed1137" + }, + "RequestBody": { + "name": "synmap-cou", + "format": "solr", + "synonyms": "Washington, Wash. =\u003E WA" + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "228", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:54 GMT", + "elapsed-time": "18", + "ETag": "W/\u00220x8D9E1E5F08C15AB\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0c71871d-7fc2-11ec-9740-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E5F08C15AB\u0022", + "name": "synmap-cou", + "format": "solr", + "synonyms": "Washington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0c8d6a51-7fc2-11ec-84a9-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "232", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:54 GMT", + "elapsed-time": "12", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0c8d6a51-7fc2-11ec-84a9-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E5F08C15AB\u0022", + "name": "synmap-cou", + "format": "solr", + "synonyms": "Washington, Wash. =\u003E WA", + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0ca059a5-7fc2-11ec-973a-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "228", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:54 GMT", + "elapsed-time": "7", + "ETag": "W/\u00220x8D9E1E5F08C15AB\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "0ca059a5-7fc2-11ec-973a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#synonymmaps/$entity", + "@odata.etag": "\u00220x8D9E1E5F08C15AB\u0022", + "name": "synmap-cou", + "format": "solr", + "synonyms": "Washington, Wash. =\u003E WA", + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/synonymmaps(\u0027synmap-cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "0cb50683-7fc2-11ec-a0a3-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:39:54 GMT", + "elapsed-time": "14", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "0cb50683-7fc2-11ec-a0a3-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_create_or_update_synonym_map.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_create_or_update_synonym_map.yaml deleted file mode 100644 index a4008b0dbc82..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_create_or_update_synonym_map.yaml +++ /dev/null @@ -1,245 +0,0 @@ -interactions: -- request: - body: '{"name": "test-syn-map", "format": "solr", "synonyms": "USA, United States, - United States of America\nWashington, Wash. => WA"}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '127' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search9ae91f0f.search.windows.net/synonymmaps?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search9ae91f0f.search.windows.net/$metadata#synonymmaps/$entity","@odata.etag":"\"0x8D96CA3924131D5\"","name":"test-syn-map","format":"solr","synonyms":"USA, - United States, United States of America\nWashington, Wash. => WA","encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '272' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:20:03 GMT - elapsed-time: - - '120' - etag: - - W/"0x8D96CA3924131D5" - expires: - - '-1' - location: - - https://search9ae91f0f.search.windows.net/synonymmaps('test-syn-map')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - aef405de-0a7f-11ec-bcbb-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search9ae91f0f.search.windows.net/synonymmaps?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search9ae91f0f.search.windows.net/$metadata#synonymmaps","value":[{"@odata.etag":"\"0x8D96CA3924131D5\"","name":"test-syn-map","format":"solr","synonyms":"USA, - United States, United States of America\nWashington, Wash. => WA","encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '276' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:20:03 GMT - elapsed-time: - - '28' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - af34c8b5-0a7f-11ec-bc8b-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"name": "test-syn-map", "format": "solr", "synonyms": "Washington, Wash. - => WA"}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '81' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://search9ae91f0f.search.windows.net/synonymmaps('test-syn-map')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search9ae91f0f.search.windows.net/$metadata#synonymmaps/$entity","@odata.etag":"\"0x8D96CA392577D00\"","name":"test-syn-map","format":"solr","synonyms":"Washington, - Wash. => WA","encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '226' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:20:03 GMT - elapsed-time: - - '21' - etag: - - W/"0x8D96CA392577D00" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - af3fc62d-0a7f-11ec-a9cb-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search9ae91f0f.search.windows.net/synonymmaps?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search9ae91f0f.search.windows.net/$metadata#synonymmaps","value":[{"@odata.etag":"\"0x8D96CA392577D00\"","name":"test-syn-map","format":"solr","synonyms":"Washington, - Wash. => WA","encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '230' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:20:03 GMT - elapsed-time: - - '16' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - af4af046-0a7f-11ec-b083-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search9ae91f0f.search.windows.net/synonymmaps('test-syn-map')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search9ae91f0f.search.windows.net/$metadata#synonymmaps/$entity","@odata.etag":"\"0x8D96CA392577D00\"","name":"test-syn-map","format":"solr","synonyms":"Washington, - Wash. => WA","encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '226' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:20:03 GMT - elapsed-time: - - '8' - etag: - - W/"0x8D96CA392577D00" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - af543dae-0a7f-11ec-8fd8-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_create_or_update_synonym_map_if_unchanged.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_create_or_update_synonym_map_if_unchanged.yaml deleted file mode 100644 index f5a0cb0c0469..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_create_or_update_synonym_map_if_unchanged.yaml +++ /dev/null @@ -1,163 +0,0 @@ -interactions: -- request: - body: '{"name": "test-syn-map", "format": "solr", "synonyms": "USA, United States, - United States of America\nWashington, Wash. => WA"}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '127' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search53532449.search.windows.net/synonymmaps?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search53532449.search.windows.net/$metadata#synonymmaps/$entity","@odata.etag":"\"0x8D96CA39B40781D\"","name":"test-syn-map","format":"solr","synonyms":"USA, - United States, United States of America\nWashington, Wash. => WA","encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '272' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:20:18 GMT - elapsed-time: - - '24' - etag: - - W/"0x8D96CA39B40781D" - expires: - - '-1' - location: - - https://search53532449.search.windows.net/synonymmaps('test-syn-map')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - b8062391-0a7f-11ec-a9ac-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "test-syn-map", "format": "solr", "synonyms": "Washington, Wash. - => WA"}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '81' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://search53532449.search.windows.net/synonymmaps('test-syn-map')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search53532449.search.windows.net/$metadata#synonymmaps/$entity","@odata.etag":"\"0x8D96CA39B4B0158\"","name":"test-syn-map","format":"solr","synonyms":"Washington, - Wash. => WA","encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '226' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:20:18 GMT - elapsed-time: - - '23' - etag: - - W/"0x8D96CA39B4B0158" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - b833eecb-0a7f-11ec-b01d-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"name": "test-syn-map", "format": "solr", "synonyms": "USA, United States, - United States of America\nWashington, Wash. => WA", "@odata.etag": "\"0x8D96CA39B40781D\""}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '167' - Content-Type: - - application/json - If-Match: - - '"0x8D96CA39B40781D"' - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://search53532449.search.windows.net/synonymmaps('test-syn-map')?api-version=2021-04-30-Preview - response: - body: - string: '{"error":{"code":"","message":"The precondition given in one of the - request headers evaluated to false. No change was made to the resource from - this request."}}' - headers: - cache-control: - - no-cache - content-language: - - en - content-length: - - '160' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:20:18 GMT - elapsed-time: - - '11' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - b8408779-0a7f-11ec-a1c7-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 412 - message: Precondition Failed -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_create_synonym_map.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_create_synonym_map.yaml deleted file mode 100644 index 0ccd9efcc982..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_create_synonym_map.yaml +++ /dev/null @@ -1,99 +0,0 @@ -interactions: -- request: - body: '{"name": "test-syn-map", "format": "solr", "synonyms": "USA, United States, - United States of America\nWashington, Wash. => WA"}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '127' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search78461aed.search.windows.net/synonymmaps?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search78461aed.search.windows.net/$metadata#synonymmaps/$entity","@odata.etag":"\"0x8D96CA3A3E643C0\"","name":"test-syn-map","format":"solr","synonyms":"USA, - United States, United States of America\nWashington, Wash. => WA","encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '272' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:20:33 GMT - elapsed-time: - - '169' - etag: - - W/"0x8D96CA3A3E643C0" - expires: - - '-1' - location: - - https://search78461aed.search.windows.net/synonymmaps('test-syn-map')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - c0a50a75-0a7f-11ec-9cb3-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search78461aed.search.windows.net/synonymmaps?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search78461aed.search.windows.net/$metadata#synonymmaps","value":[{"@odata.etag":"\"0x8D96CA3A3E643C0\"","name":"test-syn-map","format":"solr","synonyms":"USA, - United States, United States of America\nWashington, Wash. => WA","encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '276' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:20:33 GMT - elapsed-time: - - '23' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - c0d9f676-0a7f-11ec-b390-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_delete_synonym_map.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_delete_synonym_map.yaml deleted file mode 100644 index 93be44d19fcd..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_delete_synonym_map.yaml +++ /dev/null @@ -1,179 +0,0 @@ -interactions: -- request: - body: '{"name": "test-syn-map", "format": "solr", "synonyms": "USA, United States, - United States of America\nWashington, Wash. => WA"}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '127' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search78271aec.search.windows.net/synonymmaps?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search78271aec.search.windows.net/$metadata#synonymmaps/$entity","@odata.etag":"\"0x8D96CA3ACACBC75\"","name":"test-syn-map","format":"solr","synonyms":"USA, - United States, United States of America\nWashington, Wash. => WA","encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '272' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:20:48 GMT - elapsed-time: - - '34' - etag: - - W/"0x8D96CA3ACACBC75" - expires: - - '-1' - location: - - https://search78271aec.search.windows.net/synonymmaps('test-syn-map')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - c98079e4-0a7f-11ec-820c-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search78271aec.search.windows.net/synonymmaps?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search78271aec.search.windows.net/$metadata#synonymmaps","value":[{"@odata.etag":"\"0x8D96CA3ACACBC75\"","name":"test-syn-map","format":"solr","synonyms":"USA, - United States, United States of America\nWashington, Wash. => WA","encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '276' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:20:48 GMT - elapsed-time: - - '12' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - c9a0c267-0a7f-11ec-94fa-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '0' - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: DELETE - uri: https://search78271aec.search.windows.net/synonymmaps('test-syn-map')?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - date: - - Tue, 31 Aug 2021 17:20:48 GMT - elapsed-time: - - '18' - expires: - - '-1' - pragma: - - no-cache - request-id: - - c9a9c5e0-0a7f-11ec-a606-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 204 - message: No Content -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search78271aec.search.windows.net/synonymmaps?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search78271aec.search.windows.net/$metadata#synonymmaps","value":[]}' - headers: - cache-control: - - no-cache - content-length: - - '95' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:20:48 GMT - elapsed-time: - - '5' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - c9b32485-0a7f-11ec-aee2-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_delete_synonym_map_if_unchanged.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_delete_synonym_map_if_unchanged.yaml deleted file mode 100644 index 2b8c894b2f30..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_delete_synonym_map_if_unchanged.yaml +++ /dev/null @@ -1,158 +0,0 @@ -interactions: -- request: - body: '{"name": "test-syn-map", "format": "solr", "synonyms": "USA, United States, - United States of America\nWashington, Wash. => WA"}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '127' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchfabb2026.search.windows.net/synonymmaps?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchfabb2026.search.windows.net/$metadata#synonymmaps/$entity","@odata.etag":"\"0x8D96CA3B51CA0F8\"","name":"test-syn-map","format":"solr","synonyms":"USA, - United States, United States of America\nWashington, Wash. => WA","encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '272' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:21:02 GMT - elapsed-time: - - '27' - etag: - - W/"0x8D96CA3B51CA0F8" - expires: - - '-1' - location: - - https://searchfabb2026.search.windows.net/synonymmaps('test-syn-map')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - d1efaf0f-0a7f-11ec-8ec8-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "test-syn-map", "format": "solr", "synonyms": "W\na\ns\nh\ni\nn\ng\nt\no\nn\n,\n - \nW\na\ns\nh\n.\n \n=\n>\n \nW\nA"}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '125' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://searchfabb2026.search.windows.net/synonymmaps('test-syn-map')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchfabb2026.search.windows.net/$metadata#synonymmaps/$entity","@odata.etag":"\"0x8D96CA3B527EDAA\"","name":"test-syn-map","format":"solr","synonyms":"W\na\ns\nh\ni\nn\ng\nt\no\nn\n,\n - \nW\na\ns\nh\n.\n \n=\n>\n \nW\nA","encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '270' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:21:02 GMT - elapsed-time: - - '31' - etag: - - W/"0x8D96CA3B527EDAA" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - d2104ddf-0a7f-11ec-9e43-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '0' - If-Match: - - '"0x8D96CA3B51CA0F8"' - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: DELETE - uri: https://searchfabb2026.search.windows.net/synonymmaps('test-syn-map')?api-version=2021-04-30-Preview - response: - body: - string: '{"error":{"code":"","message":"The precondition given in one of the - request headers evaluated to false. No change was made to the resource from - this request."}}' - headers: - cache-control: - - no-cache - content-language: - - en - content-length: - - '160' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:21:02 GMT - elapsed-time: - - '13' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - d21bbc9e-0a7f-11ec-a67f-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 412 - message: Precondition Failed -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_get_synonym_map.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_get_synonym_map.yaml deleted file mode 100644 index 494d3b4cad76..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_get_synonym_map.yaml +++ /dev/null @@ -1,146 +0,0 @@ -interactions: -- request: - body: '{"name": "test-syn-map", "format": "solr", "synonyms": "USA, United States, - United States of America\nWashington, Wash. => WA"}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '127' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search299919b9.search.windows.net/synonymmaps?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search299919b9.search.windows.net/$metadata#synonymmaps/$entity","@odata.etag":"\"0x8D96CA3BD79E4BA\"","name":"test-syn-map","format":"solr","synonyms":"USA, - United States, United States of America\nWashington, Wash. => WA","encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '272' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:21:16 GMT - elapsed-time: - - '36' - etag: - - W/"0x8D96CA3BD79E4BA" - expires: - - '-1' - location: - - https://search299919b9.search.windows.net/synonymmaps('test-syn-map')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - da4e44bf-0a7f-11ec-9c6f-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search299919b9.search.windows.net/synonymmaps?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search299919b9.search.windows.net/$metadata#synonymmaps","value":[{"@odata.etag":"\"0x8D96CA3BD79E4BA\"","name":"test-syn-map","format":"solr","synonyms":"USA, - United States, United States of America\nWashington, Wash. => WA","encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '276' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:21:16 GMT - elapsed-time: - - '14' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - da6e2069-0a7f-11ec-a4fb-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search299919b9.search.windows.net/synonymmaps('test-syn-map')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search299919b9.search.windows.net/$metadata#synonymmaps/$entity","@odata.etag":"\"0x8D96CA3BD79E4BA\"","name":"test-syn-map","format":"solr","synonyms":"USA, - United States, United States of America\nWashington, Wash. => WA","encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '272' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:21:16 GMT - elapsed-time: - - '7' - etag: - - W/"0x8D96CA3BD79E4BA" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - da771ebd-0a7f-11ec-b3e7-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_get_synonym_maps.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_get_synonym_maps.yaml deleted file mode 100644 index 644045d9f210..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_index_client_synonym_map_live.test_get_synonym_maps.yaml +++ /dev/null @@ -1,152 +0,0 @@ -interactions: -- request: - body: '{"name": "test-syn-map-1", "format": "solr", "synonyms": "USA, United States, - United States of America"}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '104' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search43c51a2c.search.windows.net/synonymmaps?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search43c51a2c.search.windows.net/$metadata#synonymmaps/$entity","@odata.etag":"\"0x8D96CA3C5CCC615\"","name":"test-syn-map-1","format":"solr","synonyms":"USA, - United States, United States of America","encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '249' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:21:30 GMT - elapsed-time: - - '21' - etag: - - W/"0x8D96CA3C5CCC615" - expires: - - '-1' - location: - - https://search43c51a2c.search.windows.net/synonymmaps('test-syn-map-1')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - e29e8454-0a7f-11ec-b589-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "test-syn-map-2", "format": "solr", "synonyms": "Washington, Wash. - => WA"}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '83' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search43c51a2c.search.windows.net/synonymmaps?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search43c51a2c.search.windows.net/$metadata#synonymmaps/$entity","@odata.etag":"\"0x8D96CA3C5D6B2EF\"","name":"test-syn-map-2","format":"solr","synonyms":"Washington, - Wash. => WA","encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '228' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:21:30 GMT - elapsed-time: - - '19' - etag: - - W/"0x8D96CA3C5D6B2EF" - expires: - - '-1' - location: - - https://search43c51a2c.search.windows.net/synonymmaps('test-syn-map-2')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - e2c036ca-0a7f-11ec-abc8-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search43c51a2c.search.windows.net/synonymmaps?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search43c51a2c.search.windows.net/$metadata#synonymmaps","value":[{"@odata.etag":"\"0x8D96CA3C5CCC615\"","name":"test-syn-map-1","format":"solr","synonyms":"USA, - United States, United States of America","encryptionKey":null},{"@odata.etag":"\"0x8D96CA3C5D6B2EF\"","name":"test-syn-map-2","format":"solr","synonyms":"Washington, - Wash. => WA","encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '391' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 17:21:30 GMT - elapsed-time: - - '16' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - e2ca5393-0a7f-11ec-9e71-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.pyTestSearchIndexerClientTesttest_search_indexers.json b/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.pyTestSearchIndexerClientTesttest_search_indexers.json new file mode 100644 index 000000000000..d8fa40f05a56 --- /dev/null +++ b/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.pyTestSearchIndexerClientTesttest_search_indexers.json @@ -0,0 +1,3070 @@ +{ + "Entries": [ + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "234", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e2d4479c-7fc1-11ec-a67f-74c63bed1137" + }, + "RequestBody": { + "name": "create-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "408", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:45 GMT", + "elapsed-time": "36", + "ETag": "W/\u00220x8D9E1E5C73CF62B\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027create-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e2d4479c-7fc1-11ec-a67f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E5C73CF62B\u0022", + "name": "create-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "135", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e3432213-7fc1-11ec-a1f7-74c63bed1137" + }, + "RequestBody": { + "name": "create-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "691", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:45 GMT", + "elapsed-time": "597", + "ETag": "W/\u00220x8D9E1E5C7B5E4F0\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027create-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e3432213-7fc1-11ec-a1f7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E5C7B5E4F0\u0022", + "name": "create-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "104", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e3b74fc3-7fc1-11ec-8bf1-74c63bed1137" + }, + "RequestBody": { + "name": "create", + "dataSourceName": "create-ds", + "targetIndexName": "create-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "378", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:47 GMT", + "elapsed-time": "920", + "ETag": "W/\u00220x8D9E1E5C836C1C3\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027create\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e3b74fc3-7fc1-11ec-8bf1-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E5C836C1C3\u0022", + "name": "create", + "description": null, + "dataSourceName": "create-ds", + "skillsetName": null, + "targetIndexName": "create-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "234", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e45558c3-7fc1-11ec-b1f8-74c63bed1137" + }, + "RequestBody": { + "name": "delete-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "408", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:47 GMT", + "elapsed-time": "40", + "ETag": "W/\u00220x8D9E1E5C86AE96E\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027delete-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e45558c3-7fc1-11ec-b1f8-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E5C86AE96E\u0022", + "name": "delete-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "135", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e46c2b70-7fc1-11ec-8071-74c63bed1137" + }, + "RequestBody": { + "name": "delete-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "691", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:47 GMT", + "elapsed-time": "603", + "ETag": "W/\u00220x8D9E1E5C8D7CC0A\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027delete-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e46c2b70-7fc1-11ec-8071-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E5C8D7CC0A\u0022", + "name": "delete-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "104", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e4d90e78-7fc1-11ec-8d0d-74c63bed1137" + }, + "RequestBody": { + "name": "delete", + "dataSourceName": "delete-ds", + "targetIndexName": "delete-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "378", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:48 GMT", + "elapsed-time": "419", + "ETag": "W/\u00220x8D9E1E5C916EE94\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027delete\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e4d90e78-7fc1-11ec-8d0d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E5C916EE94\u0022", + "name": "delete", + "description": null, + "dataSourceName": "delete-ds", + "skillsetName": null, + "targetIndexName": "delete-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e52ab3b6-7fc1-11ec-8749-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "669", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:48 GMT", + "elapsed-time": "17", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e52ab3b6-7fc1-11ec-8749-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E5C836C1C3\u0022", + "name": "create", + "description": null, + "dataSourceName": "create-ds", + "skillsetName": null, + "targetIndexName": "create-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5C916EE94\u0022", + "name": "delete", + "description": null, + "dataSourceName": "delete-ds", + "skillsetName": null, + "targetIndexName": "delete-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027delete\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e5408ab6-7fc1-11ec-bebd-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:38:48 GMT", + "elapsed-time": "37", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "e5408ab6-7fc1-11ec-bebd-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e557ebce-7fc1-11ec-ada4-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "382", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:48 GMT", + "elapsed-time": "12", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e557ebce-7fc1-11ec-ada4-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E5C836C1C3\u0022", + "name": "create", + "description": null, + "dataSourceName": "create-ds", + "skillsetName": null, + "targetIndexName": "create-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "231", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e56ba061-7fc1-11ec-a93a-74c63bed1137" + }, + "RequestBody": { + "name": "get-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "405", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:48 GMT", + "elapsed-time": "42", + "ETag": "W/\u00220x8D9E1E5C981AE9B\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027get-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e56ba061-7fc1-11ec-a93a-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E5C981AE9B\u0022", + "name": "get-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "132", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e582f290-7fc1-11ec-8aaf-74c63bed1137" + }, + "RequestBody": { + "name": "get-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "688", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:50 GMT", + "elapsed-time": "568", + "ETag": "W/\u00220x8D9E1E5C9E93AD1\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027get-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e582f290-7fc1-11ec-8aaf-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E5C9E93AD1\u0022", + "name": "get-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "95", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e5ebe51e-7fc1-11ec-a536-74c63bed1137" + }, + "RequestBody": { + "name": "get", + "dataSourceName": "get-ds", + "targetIndexName": "get-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "369", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:50 GMT", + "elapsed-time": "567", + "ETag": "W/\u00220x8D9E1E5CA3F165B\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027get\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e5ebe51e-7fc1-11ec-a536-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E5CA3F165B\u0022", + "name": "get", + "description": null, + "dataSourceName": "get-ds", + "skillsetName": null, + "targetIndexName": "get-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027get\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e653f24b-7fc1-11ec-8794-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "369", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:50 GMT", + "elapsed-time": "7", + "ETag": "W/\u00220x8D9E1E5CA3F165B\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e653f24b-7fc1-11ec-8794-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E5CA3F165B\u0022", + "name": "get", + "description": null, + "dataSourceName": "get-ds", + "skillsetName": null, + "targetIndexName": "get-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "233", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e6669135-7fc1-11ec-b3f4-74c63bed1137" + }, + "RequestBody": { + "name": "list1-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "407", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:51 GMT", + "elapsed-time": "154", + "ETag": "W/\u00220x8D9E1E5CA8E1522\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027list1-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e6669135-7fc1-11ec-b3f4-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E5CA8E1522\u0022", + "name": "list1-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "134", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e68f2c59-7fc1-11ec-b6f7-74c63bed1137" + }, + "RequestBody": { + "name": "list1-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "690", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:51 GMT", + "elapsed-time": "636", + "ETag": "W/\u00220x8D9E1E5CB00EA3A\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027list1-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e68f2c59-7fc1-11ec-b6f7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E5CB00EA3A\u0022", + "name": "list1-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "233", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e7020680-7fc1-11ec-a372-74c63bed1137" + }, + "RequestBody": { + "name": "list2-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "407", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:51 GMT", + "elapsed-time": "42", + "ETag": "W/\u00220x8D9E1E5CB1BC147\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027list2-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e7020680-7fc1-11ec-a372-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E5CB1BC147\u0022", + "name": "list2-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "134", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e71c0c52-7fc1-11ec-a5b4-74c63bed1137" + }, + "RequestBody": { + "name": "list2-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "690", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:53 GMT", + "elapsed-time": "569", + "ETag": "W/\u00220x8D9E1E5CBAACCD1\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027list2-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e71c0c52-7fc1-11ec-a5b4-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E5CBAACCD1\u0022", + "name": "list2-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "101", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e7abedd6-7fc1-11ec-8151-74c63bed1137" + }, + "RequestBody": { + "name": "list1", + "dataSourceName": "list1-ds", + "targetIndexName": "list1-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "375", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:53 GMT", + "elapsed-time": "445", + "ETag": "W/\u00220x8D9E1E5CBEE5B8B\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027list1\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e7abedd6-7fc1-11ec-8151-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E5CBEE5B8B\u0022", + "name": "list1", + "description": null, + "dataSourceName": "list1-ds", + "skillsetName": null, + "targetIndexName": "list1-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "101", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e80215f0-7fc1-11ec-aa5e-74c63bed1137" + }, + "RequestBody": { + "name": "list2", + "dataSourceName": "list2-ds", + "targetIndexName": "list2-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "375", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:54 GMT", + "elapsed-time": "484", + "ETag": "W/\u00220x8D9E1E5CC41C678\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027list2\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e80215f0-7fc1-11ec-aa5e-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E5CC41C678\u0022", + "name": "list2", + "description": null, + "dataSourceName": "list2-ds", + "skillsetName": null, + "targetIndexName": "list2-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e85cfc40-7fc1-11ec-8672-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1228", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:54 GMT", + "elapsed-time": "29", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e85cfc40-7fc1-11ec-8672-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E5C836C1C3\u0022", + "name": "create", + "description": null, + "dataSourceName": "create-ds", + "skillsetName": null, + "targetIndexName": "create-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5CA3F165B\u0022", + "name": "get", + "description": null, + "dataSourceName": "get-ds", + "skillsetName": null, + "targetIndexName": "get-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5CBEE5B8B\u0022", + "name": "list1", + "description": null, + "dataSourceName": "list1-ds", + "skillsetName": null, + "targetIndexName": "list1-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5CC41C678\u0022", + "name": "list2", + "description": null, + "dataSourceName": "list2-ds", + "skillsetName": null, + "targetIndexName": "list2-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "231", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e87450e0-7fc1-11ec-909c-74c63bed1137" + }, + "RequestBody": { + "name": "cou-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "405", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:54 GMT", + "elapsed-time": "98", + "ETag": "W/\u00220x8D9E1E5CC8FB3E6\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027cou-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e87450e0-7fc1-11ec-909c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E5CC8FB3E6\u0022", + "name": "cou-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "132", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e8944de1-7fc1-11ec-b332-74c63bed1137" + }, + "RequestBody": { + "name": "cou-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "688", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:55 GMT", + "elapsed-time": "616", + "ETag": "W/\u00220x8D9E1E5CD2A0868\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027cou-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e8944de1-7fc1-11ec-b332-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E5CD2A0868\u0022", + "name": "cou-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "95", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e92b194f-7fc1-11ec-8af7-74c63bed1137" + }, + "RequestBody": { + "name": "cou", + "dataSourceName": "cou-ds", + "targetIndexName": "cou-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "369", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:55 GMT", + "elapsed-time": "435", + "ETag": "W/\u00220x8D9E1E5CD6A3C45\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027cou\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e92b194f-7fc1-11ec-8af7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E5CD6A3C45\u0022", + "name": "cou", + "description": null, + "dataSourceName": "cou-ds", + "skillsetName": null, + "targetIndexName": "cou-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e97e7479-7fc1-11ec-bbcd-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1506", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:55 GMT", + "elapsed-time": "32", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e97e7479-7fc1-11ec-bbcd-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E5CD6A3C45\u0022", + "name": "cou", + "description": null, + "dataSourceName": "cou-ds", + "skillsetName": null, + "targetIndexName": "cou-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5C836C1C3\u0022", + "name": "create", + "description": null, + "dataSourceName": "create-ds", + "skillsetName": null, + "targetIndexName": "create-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5CA3F165B\u0022", + "name": "get", + "description": null, + "dataSourceName": "get-ds", + "skillsetName": null, + "targetIndexName": "get-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5CBEE5B8B\u0022", + "name": "list1", + "description": null, + "dataSourceName": "list1-ds", + "skillsetName": null, + "targetIndexName": "list1-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5CC41C678\u0022", + "name": "list2", + "description": null, + "dataSourceName": "list2-ds", + "skillsetName": null, + "targetIndexName": "list2-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "121", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e995c9d9-7fc1-11ec-9a28-74c63bed1137" + }, + "RequestBody": { + "name": "cou", + "description": "updated", + "dataSourceName": "cou-ds", + "targetIndexName": "cou-hotels", + "disabled": false + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "374", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:56 GMT", + "elapsed-time": "341", + "ETag": "W/\u00220x8D9E1E5CDDA0499\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e995c9d9-7fc1-11ec-9a28-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E5CDDA0499\u0022", + "name": "cou", + "description": "updated", + "dataSourceName": "cou-ds", + "skillsetName": null, + "targetIndexName": "cou-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e9db19c3-7fc1-11ec-bcd1-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1511", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:56 GMT", + "elapsed-time": "31", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e9db19c3-7fc1-11ec-bcd1-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers", + "value": [ + { + "@odata.etag": "\u00220x8D9E1E5CDDA0499\u0022", + "name": "cou", + "description": "updated", + "dataSourceName": "cou-ds", + "skillsetName": null, + "targetIndexName": "cou-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5C836C1C3\u0022", + "name": "create", + "description": null, + "dataSourceName": "create-ds", + "skillsetName": null, + "targetIndexName": "create-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5CA3F165B\u0022", + "name": "get", + "description": null, + "dataSourceName": "get-ds", + "skillsetName": null, + "targetIndexName": "get-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5CBEE5B8B\u0022", + "name": "list1", + "description": null, + "dataSourceName": "list1-ds", + "skillsetName": null, + "targetIndexName": "list1-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + }, + { + "@odata.etag": "\u00220x8D9E1E5CC41C678\u0022", + "name": "list2", + "description": null, + "dataSourceName": "list2-ds", + "skillsetName": null, + "targetIndexName": "list2-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + ] + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027cou\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "e9f1452d-7fc1-11ec-8fd7-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "374", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:56 GMT", + "elapsed-time": "7", + "ETag": "W/\u00220x8D9E1E5CDDA0499\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "e9f1452d-7fc1-11ec-8fd7-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E5CDDA0499\u0022", + "name": "cou", + "description": "updated", + "dataSourceName": "cou-ds", + "skillsetName": null, + "targetIndexName": "cou-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "233", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ea03a8ad-7fc1-11ec-a9a4-74c63bed1137" + }, + "RequestBody": { + "name": "reset-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "407", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:56 GMT", + "elapsed-time": "81", + "ETag": "W/\u00220x8D9E1E5CE20520C\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027reset-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ea03a8ad-7fc1-11ec-a9a4-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E5CE20520C\u0022", + "name": "reset-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "134", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ea21687b-7fc1-11ec-bd75-74c63bed1137" + }, + "RequestBody": { + "name": "reset-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "690", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:57 GMT", + "elapsed-time": "631", + "ETag": "W/\u00220x8D9E1E5CE92B221\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027reset-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ea21687b-7fc1-11ec-bd75-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E5CE92B221\u0022", + "name": "reset-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "101", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ea93b654-7fc1-11ec-929c-74c63bed1137" + }, + "RequestBody": { + "name": "reset", + "dataSourceName": "reset-ds", + "targetIndexName": "reset-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "375", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:57 GMT", + "elapsed-time": "442", + "ETag": "W/\u00220x8D9E1E5CED222BB\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027reset\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ea93b654-7fc1-11ec-929c-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E5CED222BB\u0022", + "name": "reset", + "description": null, + "dataSourceName": "reset-ds", + "skillsetName": null, + "targetIndexName": "reset-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027reset\u0027)/search.reset?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "eae87177-7fc1-11ec-9ecd-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 204, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Date": "Thu, 27 Jan 2022 22:38:58 GMT", + "elapsed-time": "352", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "eae87177-7fc1-11ec-9ecd-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027reset\u0027)/search.status?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "eb2ecb70-7fc1-11ec-8a87-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "1039", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:58 GMT", + "elapsed-time": "16", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "eb2ecb70-7fc1-11ec-8a87-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#Microsoft.Azure.Search.V2021_04_30_Preview.IndexerExecutionInfo", + "name": "reset", + "status": "running", + "lastResult": { + "status": "reset", + "statusDetail": null, + "errorMessage": null, + "startTime": "2022-01-27T22:38:58.602Z", + "endTime": "2022-01-27T22:38:58.602Z", + "itemsProcessed": 0, + "itemsFailed": 0, + "initialTrackingState": null, + "finalTrackingState": null, + "mode": "indexingAllDocs", + "errors": [], + "warnings": [], + "metrics": null + }, + "executionHistory": [ + { + "status": "reset", + "statusDetail": null, + "errorMessage": null, + "startTime": "2022-01-27T22:38:58.602Z", + "endTime": "2022-01-27T22:38:58.602Z", + "itemsProcessed": 0, + "itemsFailed": 0, + "initialTrackingState": null, + "finalTrackingState": null, + "mode": "indexingAllDocs", + "errors": [], + "warnings": [], + "metrics": null + } + ], + "limits": null, + "currentState": { + "mode": "indexingAllDocs", + "allDocsInitialTrackingState": null, + "allDocsFinalTrackingState": null, + "resetDocsInitialTrackingState": null, + "resetDocsFinalTrackingState": null, + "resetDocumentKeys": [], + "resetDatasourceDocumentIds": [] + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "231", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "eb44c2b7-7fc1-11ec-8593-74c63bed1137" + }, + "RequestBody": { + "name": "run-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "405", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:58 GMT", + "elapsed-time": "103", + "ETag": "W/\u00220x8D9E1E5CF654C5D\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027run-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "eb44c2b7-7fc1-11ec-8593-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E5CF654C5D\u0022", + "name": "run-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "132", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "eb665688-7fc1-11ec-bf57-74c63bed1137" + }, + "RequestBody": { + "name": "run-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "688", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:59 GMT", + "elapsed-time": "535", + "ETag": "W/\u00220x8D9E1E5CFC8BA7B\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027run-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "eb665688-7fc1-11ec-bf57-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E5CFC8BA7B\u0022", + "name": "run-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "95", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ebc9a8fc-7fc1-11ec-ac6d-74c63bed1137" + }, + "RequestBody": { + "name": "run", + "dataSourceName": "run-ds", + "targetIndexName": "run-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "369", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:59 GMT", + "elapsed-time": "465", + "ETag": "W/\u00220x8D9E1E5D00A4DAC\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027run\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ebc9a8fc-7fc1-11ec-ac6d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E5D00A4DAC\u0022", + "name": "run", + "description": null, + "dataSourceName": "run-ds", + "skillsetName": null, + "targetIndexName": "run-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027run\u0027)/search.run?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ec22f946-7fc1-11ec-bc21-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 202, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "0", + "Date": "Thu, 27 Jan 2022 22:38:59 GMT", + "elapsed-time": "44", + "Expires": "-1", + "Pragma": "no-cache", + "request-id": "ec22f946-7fc1-11ec-bc21-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": null + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027run\u0027)/search.status?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ec3b1208-7fc1-11ec-b0cc-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "552", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:38:59 GMT", + "elapsed-time": "15", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ec3b1208-7fc1-11ec-b0cc-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#Microsoft.Azure.Search.V2021_04_30_Preview.IndexerExecutionInfo", + "name": "run", + "status": "running", + "lastResult": null, + "executionHistory": [], + "limits": { + "maxRunTime": "PT0S", + "maxDocumentExtractionSize": 0, + "maxDocumentContentCharactersToExtract": 0 + }, + "currentState": { + "mode": "indexingAllDocs", + "allDocsInitialTrackingState": null, + "allDocsFinalTrackingState": null, + "resetDocsInitialTrackingState": null, + "resetDocsFinalTrackingState": null, + "resetDocumentKeys": [], + "resetDatasourceDocumentIds": [] + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "238", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ec4ec148-7fc1-11ec-a321-74c63bed1137" + }, + "RequestBody": { + "name": "get-status-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "412", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:00 GMT", + "elapsed-time": "55", + "ETag": "W/\u00220x8D9E1E5D068B375\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027get-status-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ec4ec148-7fc1-11ec-a321-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E5D068B375\u0022", + "name": "get-status-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "139", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ec696fa4-7fc1-11ec-9388-74c63bed1137" + }, + "RequestBody": { + "name": "get-status-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "695", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:00 GMT", + "elapsed-time": "571", + "ETag": "W/\u00220x8D9E1E5D0CDCF04\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027get-status-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ec696fa4-7fc1-11ec-9388-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E5D0CDCF04\u0022", + "name": "get-status-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "116", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ecd310eb-7fc1-11ec-a64d-74c63bed1137" + }, + "RequestBody": { + "name": "get-status", + "dataSourceName": "get-status-ds", + "targetIndexName": "get-status-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "390", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:02 GMT", + "elapsed-time": "483", + "ETag": "W/\u00220x8D9E1E5D111D2DA\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027get-status\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ecd310eb-7fc1-11ec-a64d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E5D111D2DA\u0022", + "name": "get-status", + "description": null, + "dataSourceName": "get-status-ds", + "skillsetName": null, + "targetIndexName": "get-status-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027get-status\u0027)/search.status?api-version=2021-04-30-Preview", + "RequestMethod": "GET", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ed2e0831-7fc1-11ec-9e76-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "559", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:02 GMT", + "elapsed-time": "15", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ed2e0831-7fc1-11ec-9e76-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#Microsoft.Azure.Search.V2021_04_30_Preview.IndexerExecutionInfo", + "name": "get-status", + "status": "running", + "lastResult": null, + "executionHistory": [], + "limits": { + "maxRunTime": "PT0S", + "maxDocumentExtractionSize": 0, + "maxDocumentContentCharactersToExtract": 0 + }, + "currentState": { + "mode": "indexingAllDocs", + "allDocsInitialTrackingState": null, + "allDocsFinalTrackingState": null, + "resetDocsInitialTrackingState": null, + "resetDocsFinalTrackingState": null, + "resetDocumentKeys": [], + "resetDatasourceDocumentIds": [] + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "235", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ed41a990-7fc1-11ec-965b-74c63bed1137" + }, + "RequestBody": { + "name": "couunch-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "409", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:02 GMT", + "elapsed-time": "97", + "ETag": "W/\u00220x8D9E1E5D15D0197\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027couunch-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ed41a990-7fc1-11ec-965b-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E5D15D0197\u0022", + "name": "couunch-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "136", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ed62401f-7fc1-11ec-b931-74c63bed1137" + }, + "RequestBody": { + "name": "couunch-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "692", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:03 GMT", + "elapsed-time": "601", + "ETag": "W/\u00220x8D9E1E5D1CE7762\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027couunch-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ed62401f-7fc1-11ec-b931-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E5D1CE7762\u0022", + "name": "couunch-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "107", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "edcfafb0-7fc1-11ec-bb3f-74c63bed1137" + }, + "RequestBody": { + "name": "couunch", + "dataSourceName": "couunch-ds", + "targetIndexName": "couunch-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "381", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:03 GMT", + "elapsed-time": "430", + "ETag": "W/\u00220x8D9E1E5D20C61A3\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027couunch\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "edcfafb0-7fc1-11ec-bb3f-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E5D20C61A3\u0022", + "name": "couunch", + "description": null, + "dataSourceName": "couunch-ds", + "skillsetName": null, + "targetIndexName": "couunch-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027couunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "133", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ee2280d4-7fc1-11ec-baf0-74c63bed1137" + }, + "RequestBody": { + "name": "couunch", + "description": "updated", + "dataSourceName": "couunch-ds", + "targetIndexName": "couunch-hotels", + "disabled": false + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "386", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:03 GMT", + "elapsed-time": "310", + "ETag": "W/\u00220x8D9E1E5D2621620\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ee2280d4-7fc1-11ec-baf0-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E5D2621620\u0022", + "name": "couunch", + "description": "updated", + "dataSourceName": "couunch-ds", + "skillsetName": null, + "targetIndexName": "couunch-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027couunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "173", + "Content-Type": "application/json", + "If-Match": "\u00220x8D9E1E5D20C61A3\u0022", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ee62f96d-7fc1-11ec-8337-74c63bed1137" + }, + "RequestBody": { + "name": "couunch", + "description": "updated", + "dataSourceName": "couunch-ds", + "targetIndexName": "couunch-hotels", + "disabled": false, + "@odata.etag": "\u00220x8D9E1E5D20C61A3\u0022" + }, + "StatusCode": 412, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "160", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:04 GMT", + "elapsed-time": "8", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ee62f96d-7fc1-11ec-8337-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "The precondition given in one of the request headers evaluated to false. No change was made to the resource from this request." + } + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/datasources?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "235", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ee74a01a-7fc1-11ec-ae3d-74c63bed1137" + }, + "RequestBody": { + "name": "delunch-ds", + "type": "azureblob", + "credentials": { + "connectionString": "DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net" + }, + "container": { + "name": "fakestoragecontainer" + } + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "409", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:04 GMT", + "elapsed-time": "61", + "ETag": "W/\u00220x8D9E1E5D28DDAA1\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/datasources(\u0027delunch-ds\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ee74a01a-7fc1-11ec-ae3d-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#datasources/$entity", + "@odata.etag": "\u00220x8D9E1E5D28DDAA1\u0022", + "name": "delunch-ds", + "description": null, + "type": "azureblob", + "subtype": null, + "credentials": { + "connectionString": null + }, + "container": { + "name": "fakestoragecontainer", + "query": null + }, + "dataChangeDetectionPolicy": null, + "dataDeletionDetectionPolicy": null, + "encryptionKey": null, + "identity": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexes?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "136", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ee8eddf2-7fc1-11ec-8d1e-74c63bed1137" + }, + "RequestBody": { + "name": "delunch-hotels", + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "key": true, + "retrievable": true, + "searchable": false + } + ] + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "692", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:04 GMT", + "elapsed-time": "668", + "ETag": "W/\u00220x8D9E1E5D3039585\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexes(\u0027delunch-hotels\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ee8eddf2-7fc1-11ec-8d1e-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexes/$entity", + "@odata.etag": "\u00220x8D9E1E5D3039585\u0022", + "name": "delunch-hotels", + "defaultScoringProfile": null, + "fields": [ + { + "name": "hotelId", + "type": "Edm.String", + "searchable": false, + "filterable": true, + "retrievable": true, + "sortable": true, + "facetable": true, + "key": true, + "indexAnalyzer": null, + "searchAnalyzer": null, + "analyzer": null, + "normalizer": null, + "synonymMaps": [] + } + ], + "scoringProfiles": [], + "corsOptions": null, + "suggesters": [], + "analyzers": [], + "normalizers": [], + "tokenizers": [], + "tokenFilters": [], + "charFilters": [], + "encryptionKey": null, + "similarity": { + "@odata.type": "#Microsoft.Azure.Search.BM25Similarity", + "k1": null, + "b": null + }, + "semantic": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers?api-version=2021-04-30-Preview", + "RequestMethod": "POST", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "107", + "Content-Type": "application/json", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ef05e82d-7fc1-11ec-a0b0-74c63bed1137" + }, + "RequestBody": { + "name": "delunch", + "dataSourceName": "delunch-ds", + "targetIndexName": "delunch-hotels", + "disabled": false + }, + "StatusCode": 201, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Length": "381", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:05 GMT", + "elapsed-time": "442", + "ETag": "W/\u00220x8D9E1E5D343A258\u0022", + "Expires": "-1", + "Location": "https://fakesearchendpoint.search.windows.net/indexers(\u0027delunch\u0027)?api-version=2021-04-30-Preview", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ef05e82d-7fc1-11ec-a0b0-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E5D343A258\u0022", + "name": "delunch", + "description": null, + "dataSourceName": "delunch-ds", + "skillsetName": null, + "targetIndexName": "delunch-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027delunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "PUT", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "133", + "Content-Type": "application/json", + "Prefer": "return=representation", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ef5a9ce4-7fc1-11ec-8566-74c63bed1137" + }, + "RequestBody": { + "name": "delunch", + "description": "updated", + "dataSourceName": "delunch-ds", + "targetIndexName": "delunch-hotels", + "disabled": false + }, + "StatusCode": 200, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Encoding": "gzip", + "Content-Length": "386", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:05 GMT", + "elapsed-time": "288", + "ETag": "W/\u00220x8D9E1E5D3973448\u0022", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ef5a9ce4-7fc1-11ec-8566-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains", + "Vary": "Accept-Encoding" + }, + "ResponseBody": { + "@odata.context": "https://fakesearchendpoint.search.windows.net/$metadata#indexers/$entity", + "@odata.etag": "\u00220x8D9E1E5D3973448\u0022", + "name": "delunch", + "description": "updated", + "dataSourceName": "delunch-ds", + "skillsetName": null, + "targetIndexName": "delunch-hotels", + "disabled": false, + "schedule": null, + "parameters": null, + "fieldMappings": [], + "outputFieldMappings": [], + "cache": null, + "encryptionKey": null + } + }, + { + "RequestUri": "https://fakesearchendpoint.search.windows.net/indexers(\u0027delunch\u0027)?api-version=2021-04-30-Preview", + "RequestMethod": "DELETE", + "RequestHeaders": { + "Accept": "application/json;odata.metadata=minimal", + "Accept-Encoding": "gzip, deflate", + "Connection": "keep-alive", + "Content-Length": "0", + "If-Match": "\u00220x8D9E1E5D343A258\u0022", + "User-Agent": "azsdk-python-search-documents/11.3.0b7 Python/3.9.2 (Windows-10-10.0.19041-SP0)", + "x-ms-client-request-id": "ef98044c-7fc1-11ec-a6e3-74c63bed1137" + }, + "RequestBody": null, + "StatusCode": 412, + "ResponseHeaders": { + "Cache-Control": "no-cache", + "Content-Language": "en", + "Content-Length": "160", + "Content-Type": "application/json; odata.metadata=minimal", + "Date": "Thu, 27 Jan 2022 22:39:05 GMT", + "elapsed-time": "7", + "Expires": "-1", + "OData-Version": "4.0", + "Pragma": "no-cache", + "Preference-Applied": "odata.include-annotations=\u0022*\u0022", + "request-id": "ef98044c-7fc1-11ec-a6e3-74c63bed1137", + "Strict-Transport-Security": "max-age=15724800; includeSubDomains" + }, + "ResponseBody": { + "error": { + "code": "", + "message": "The precondition given in one of the request headers evaluated to false. No change was made to the resource from this request." + } + } + } + ], + "Variables": {} +} diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_create_indexer.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_create_indexer.yaml deleted file mode 100644 index 25e0893f6857..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_create_indexer.yaml +++ /dev/null @@ -1,155 +0,0 @@ -interactions: -- request: - body: '{"name": "sample-datasource", "type": "azureblob", "credentials": {"connectionString": - "connection_string"}, "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '325' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search207914e0.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search207914e0.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CBA11CE349A\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '407' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:01:06 GMT - elapsed-time: - - '43' - etag: - - W/"0x8D96CBA11CE349A" - expires: - - '-1' - location: - - https://search207914e0.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 2eaa49c0-0a96-11ec-98ed-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "hotels", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '128' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search207914e0.search.windows.net/indexes?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search207914e0.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CBA125296E4\"","name":"hotels","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}],"scoringProfiles":[],"corsOptions":null,"suggesters":[],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '664' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:01:07 GMT - elapsed-time: - - '644' - etag: - - W/"0x8D96CBA125296E4" - expires: - - '-1' - location: - - https://search207914e0.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 2ee7dedb-0a96-11ec-b6f9-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "sample-indexer", "dataSourceName": "sample-datasource", "targetIndexName": - "hotels", "disabled": false}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '113' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search207914e0.search.windows.net/indexers?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search207914e0.search.windows.net/$metadata#indexers/$entity","@odata.etag":"\"0x8D96CBA12A6E018\"","name":"sample-indexer","description":null,"dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '383' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:01:08 GMT - elapsed-time: - - '418' - etag: - - W/"0x8D96CBA12A6E018" - expires: - - '-1' - location: - - https://search207914e0.search.windows.net/indexers('sample-indexer')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 2f6b4466-0a96-11ec-857f-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_create_or_update_indexer.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_create_or_update_indexer.yaml deleted file mode 100644 index 225e40a61525..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_create_or_update_indexer.yaml +++ /dev/null @@ -1,342 +0,0 @@ -interactions: -- request: - body: '{"name": "sample-datasource", "type": "azureblob", "credentials": {"connectionString": - "connection_string"}, "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '325' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search8001902.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search8001902.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CBA1C34B154\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '406' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:01:24 GMT - elapsed-time: - - '47' - etag: - - W/"0x8D96CBA1C34B154" - expires: - - '-1' - location: - - https://search8001902.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 391b488f-0a96-11ec-852c-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "hotels", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '128' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search8001902.search.windows.net/indexes?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search8001902.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CBA1CACB563\"","name":"hotels","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}],"scoringProfiles":[],"corsOptions":null,"suggesters":[],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '663' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:01:25 GMT - elapsed-time: - - '587' - etag: - - W/"0x8D96CBA1CACB563" - expires: - - '-1' - location: - - https://search8001902.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 394d20e3-0a96-11ec-b908-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "sample-indexer", "dataSourceName": "sample-datasource", "targetIndexName": - "hotels", "disabled": false}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '113' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search8001902.search.windows.net/indexers?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search8001902.search.windows.net/$metadata#indexers/$entity","@odata.etag":"\"0x8D96CBA1D1EC4FF\"","name":"sample-indexer","description":null,"dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '382' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:01:25 GMT - elapsed-time: - - '629' - etag: - - W/"0x8D96CBA1D1EC4FF" - expires: - - '-1' - location: - - https://search8001902.search.windows.net/indexers('sample-indexer')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 39c58cb0-0a96-11ec-9961-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search8001902.search.windows.net/indexers?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search8001902.search.windows.net/$metadata#indexers","value":[{"@odata.etag":"\"0x8D96CBA1D1EC4FF\"","name":"sample-indexer","description":null,"dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '386' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:01:25 GMT - elapsed-time: - - '23' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 3a49193f-0a96-11ec-8993-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"name": "sample-indexer", "description": "updated", "dataSourceName": - "sample-datasource", "targetIndexName": "hotels", "disabled": false}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '139' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://search8001902.search.windows.net/indexers('sample-indexer')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search8001902.search.windows.net/$metadata#indexers/$entity","@odata.etag":"\"0x8D96CBA1D700066\"","name":"sample-indexer","description":"updated","dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '387' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:01:26 GMT - elapsed-time: - - '291' - etag: - - W/"0x8D96CBA1D700066" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 3a5460d0-0a96-11ec-ab83-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search8001902.search.windows.net/indexers?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search8001902.search.windows.net/$metadata#indexers","value":[{"@odata.etag":"\"0x8D96CBA1D700066\"","name":"sample-indexer","description":"updated","dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '391' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:01:26 GMT - elapsed-time: - - '45' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 3a8acbff-0a96-11ec-9c75-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search8001902.search.windows.net/indexers('sample-indexer')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search8001902.search.windows.net/$metadata#indexers/$entity","@odata.etag":"\"0x8D96CBA1D700066\"","name":"sample-indexer","description":"updated","dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '387' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:01:26 GMT - elapsed-time: - - '8' - etag: - - W/"0x8D96CBA1D700066" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 3a9d8b9a-0a96-11ec-85ab-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_create_or_update_indexer_if_unchanged.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_create_or_update_indexer_if_unchanged.yaml deleted file mode 100644 index 11d9b6c59f7e..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_create_or_update_indexer_if_unchanged.yaml +++ /dev/null @@ -1,264 +0,0 @@ -interactions: -- request: - body: '{"name": "sample-datasource", "type": "azureblob", "credentials": {"connectionString": - "connection_string"}, "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '325' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search71b21e3c.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search71b21e3c.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CBA26F7B616\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '407' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:01:42 GMT - elapsed-time: - - '39' - etag: - - W/"0x8D96CBA26F7B616" - expires: - - '-1' - location: - - https://search71b21e3c.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 43e664ea-0a96-11ec-9bef-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "hotels", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '128' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search71b21e3c.search.windows.net/indexes?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search71b21e3c.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CBA277C8D9E\"","name":"hotels","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}],"scoringProfiles":[],"corsOptions":null,"suggesters":[],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '664' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:01:43 GMT - elapsed-time: - - '662' - etag: - - W/"0x8D96CBA277C8D9E" - expires: - - '-1' - location: - - https://search71b21e3c.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 44113a6c-0a96-11ec-a069-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "sample-indexer", "dataSourceName": "sample-datasource", "targetIndexName": - "hotels", "disabled": false}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '113' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search71b21e3c.search.windows.net/indexers?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search71b21e3c.search.windows.net/$metadata#indexers/$entity","@odata.etag":"\"0x8D96CBA28C3503E\"","name":"sample-indexer","description":null,"dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '383' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:01:45 GMT - elapsed-time: - - '2035' - etag: - - W/"0x8D96CBA28C3503E" - expires: - - '-1' - location: - - https://search71b21e3c.search.windows.net/indexers('sample-indexer')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 4495150b-0a96-11ec-9382-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "sample-indexer", "description": "updated", "dataSourceName": - "sample-datasource", "targetIndexName": "hotels", "disabled": false}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '139' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://search71b21e3c.search.windows.net/indexers('sample-indexer')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search71b21e3c.search.windows.net/$metadata#indexers/$entity","@odata.etag":"\"0x8D96CBA294C1FF3\"","name":"sample-indexer","description":"updated","dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '388' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:01:45 GMT - elapsed-time: - - '702' - etag: - - W/"0x8D96CBA294C1FF3" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 45f19f00-0a96-11ec-a9a2-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: '{"name": "sample-indexer", "description": "updated", "dataSourceName": - "sample-datasource", "targetIndexName": "hotels", "disabled": false, "@odata.etag": - "\"0x8D96CBA28C3503E\""}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '179' - Content-Type: - - application/json - If-Match: - - '"0x8D96CBA28C3503E"' - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://search71b21e3c.search.windows.net/indexers('sample-indexer')?api-version=2021-04-30-Preview - response: - body: - string: '{"error":{"code":"","message":"The precondition given in one of the - request headers evaluated to false. No change was made to the resource from - this request."}}' - headers: - cache-control: - - no-cache - content-language: - - en - content-length: - - '160' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:01:45 GMT - elapsed-time: - - '9' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 4665ed00-0a96-11ec-b5fa-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 412 - message: Precondition Failed -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_delete_indexer.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_delete_indexer.yaml deleted file mode 100644 index cdf3eb09783f..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_delete_indexer.yaml +++ /dev/null @@ -1,279 +0,0 @@ -interactions: -- request: - body: '{"name": "sample-datasource", "type": "azureblob", "credentials": {"connectionString": - "connection_string"}, "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '325' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search205e14df.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search205e14df.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CBA325827B8\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '407' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:02:01 GMT - elapsed-time: - - '155' - etag: - - W/"0x8D96CBA325827B8" - expires: - - '-1' - location: - - https://search205e14df.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 4f375e77-0a96-11ec-af93-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "hotels", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '128' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search205e14df.search.windows.net/indexes?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search205e14df.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CBA32EBA7CA\"","name":"hotels","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}],"scoringProfiles":[],"corsOptions":null,"suggesters":[],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '664' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:02:01 GMT - elapsed-time: - - '672' - etag: - - W/"0x8D96CBA32EBA7CA" - expires: - - '-1' - location: - - https://search205e14df.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 4f7198f7-0a96-11ec-953d-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "sample-indexer", "dataSourceName": "sample-datasource", "targetIndexName": - "hotels", "disabled": false}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '113' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search205e14df.search.windows.net/indexers?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search205e14df.search.windows.net/$metadata#indexers/$entity","@odata.etag":"\"0x8D96CBA3D6D0434\"","name":"sample-indexer","description":null,"dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '383' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:02:19 GMT - elapsed-time: - - '17618' - etag: - - W/"0x8D96CBA3D6D0434" - expires: - - '-1' - location: - - https://search205e14df.search.windows.net/indexers('sample-indexer')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 50041593-0a96-11ec-8257-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search205e14df.search.windows.net/indexers?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search205e14df.search.windows.net/$metadata#indexers","value":[{"@odata.etag":"\"0x8D96CBA3D6D0434\"","name":"sample-indexer","description":null,"dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '387' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:02:19 GMT - elapsed-time: - - '27' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 5aa8c026-0a96-11ec-b0cd-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '0' - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: DELETE - uri: https://search205e14df.search.windows.net/indexers('sample-indexer')?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - date: - - Tue, 31 Aug 2021 20:02:19 GMT - elapsed-time: - - '46' - expires: - - '-1' - pragma: - - no-cache - request-id: - - 5ab65127-0a96-11ec-939e-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 204 - message: No Content -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search205e14df.search.windows.net/indexers?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search205e14df.search.windows.net/$metadata#indexers","value":[]}' - headers: - cache-control: - - no-cache - content-length: - - '92' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:02:19 GMT - elapsed-time: - - '6' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 5ac6798c-0a96-11ec-9bed-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_delete_indexer_if_unchanged.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_delete_indexer_if_unchanged.yaml deleted file mode 100644 index c6e4db10bf79..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_delete_indexer_if_unchanged.yaml +++ /dev/null @@ -1,258 +0,0 @@ -interactions: -- request: - body: '{"name": "sample-datasource", "type": "azureblob", "credentials": {"connectionString": - "connection_string"}, "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '325' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search54491a19.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search54491a19.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CBA467F4E56\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '407' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:02:34 GMT - elapsed-time: - - '46' - etag: - - W/"0x8D96CBA467F4E56" - expires: - - '-1' - location: - - https://search54491a19.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 63701810-0a96-11ec-898c-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "hotels", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '128' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search54491a19.search.windows.net/indexes?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search54491a19.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CBA470C8BC7\"","name":"hotels","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}],"scoringProfiles":[],"corsOptions":null,"suggesters":[],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '664' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:02:36 GMT - elapsed-time: - - '555' - etag: - - W/"0x8D96CBA470C8BC7" - expires: - - '-1' - location: - - https://search54491a19.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 6398a3eb-0a96-11ec-b8d5-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "sample-indexer", "dataSourceName": "sample-datasource", "targetIndexName": - "hotels", "disabled": false}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '113' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search54491a19.search.windows.net/indexers?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search54491a19.search.windows.net/$metadata#indexers/$entity","@odata.etag":"\"0x8D96CBA47F0AAFB\"","name":"sample-indexer","description":null,"dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '383' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:02:37 GMT - elapsed-time: - - '1405' - etag: - - W/"0x8D96CBA47F0AAFB" - expires: - - '-1' - location: - - https://search54491a19.search.windows.net/indexers('sample-indexer')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 6425f217-0a96-11ec-a9ef-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "sample-indexer", "description": "updated", "dataSourceName": - "sample-datasource", "targetIndexName": "hotels", "disabled": false}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '139' - Content-Type: - - application/json - Prefer: - - return=representation - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: PUT - uri: https://search54491a19.search.windows.net/indexers('sample-indexer')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search54491a19.search.windows.net/$metadata#indexers/$entity","@odata.etag":"\"0x8D96CBA483B7CAC\"","name":"sample-indexer","description":"updated","dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '388' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:02:37 GMT - elapsed-time: - - '281' - etag: - - W/"0x8D96CBA483B7CAC" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 65204c5b-0a96-11ec-979b-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '0' - If-Match: - - '"0x8D96CBA47F0AAFB"' - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: DELETE - uri: https://search54491a19.search.windows.net/indexers('sample-indexer')?api-version=2021-04-30-Preview - response: - body: - string: '{"error":{"code":"","message":"The precondition given in one of the - request headers evaluated to false. No change was made to the resource from - this request."}}' - headers: - cache-control: - - no-cache - content-language: - - en - content-length: - - '160' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:02:37 GMT - elapsed-time: - - '23' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 6553f8f9-0a96-11ec-966c-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 412 - message: Precondition Failed -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_get_indexer.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_get_indexer.yaml deleted file mode 100644 index bb0dbda6b135..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_get_indexer.yaml +++ /dev/null @@ -1,201 +0,0 @@ -interactions: -- request: - body: '{"name": "sample-datasource", "type": "azureblob", "credentials": {"connectionString": - "connection_string"}, "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '325' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searche35313ac.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searche35313ac.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CBA51051854\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '407' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:02:51 GMT - elapsed-time: - - '39' - etag: - - W/"0x8D96CBA51051854" - expires: - - '-1' - location: - - https://searche35313ac.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 6df185e3-0a96-11ec-87b1-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "hotels", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '128' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searche35313ac.search.windows.net/indexes?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searche35313ac.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CBA51824D6F\"","name":"hotels","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}],"scoringProfiles":[],"corsOptions":null,"suggesters":[],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '664' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:02:53 GMT - elapsed-time: - - '602' - etag: - - W/"0x8D96CBA51824D6F" - expires: - - '-1' - location: - - https://searche35313ac.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 6e1de164-0a96-11ec-82eb-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "sample-indexer", "dataSourceName": "sample-datasource", "targetIndexName": - "hotels", "disabled": false}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '113' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searche35313ac.search.windows.net/indexers?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searche35313ac.search.windows.net/$metadata#indexers/$entity","@odata.etag":"\"0x8D96CBA51D16597\"","name":"sample-indexer","description":null,"dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '383' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:02:54 GMT - elapsed-time: - - '430' - etag: - - W/"0x8D96CBA51D16597" - expires: - - '-1' - location: - - https://searche35313ac.search.windows.net/indexers('sample-indexer')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 6e9adfd8-0a96-11ec-b07a-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searche35313ac.search.windows.net/indexers('sample-indexer')?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searche35313ac.search.windows.net/$metadata#indexers/$entity","@odata.etag":"\"0x8D96CBA51D16597\"","name":"sample-indexer","description":null,"dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '383' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:02:54 GMT - elapsed-time: - - '19' - etag: - - W/"0x8D96CBA51D16597" - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 6efeb795-0a96-11ec-a5dd-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_get_indexer_status.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_get_indexer_status.yaml deleted file mode 100644 index 256fc1087b65..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_get_indexer_status.yaml +++ /dev/null @@ -1,199 +0,0 @@ -interactions: -- request: - body: '{"name": "sample-datasource", "type": "azureblob", "credentials": {"connectionString": - "connection_string"}, "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '325' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search78e216af.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search78e216af.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CBA5BC20178\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '407' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:03:10 GMT - elapsed-time: - - '122' - etag: - - W/"0x8D96CBA5BC20178" - expires: - - '-1' - location: - - https://search78e216af.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 78aa78da-0a96-11ec-ba3a-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "hotels", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '128' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search78e216af.search.windows.net/indexes?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search78e216af.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CBA5C3066F0\"","name":"hotels","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}],"scoringProfiles":[],"corsOptions":null,"suggesters":[],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '664' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:03:11 GMT - elapsed-time: - - '470' - etag: - - W/"0x8D96CBA5C3066F0" - expires: - - '-1' - location: - - https://search78e216af.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 78df849a-0a96-11ec-9e1d-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "sample-indexer", "dataSourceName": "sample-datasource", "targetIndexName": - "hotels", "disabled": false}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '113' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://search78e216af.search.windows.net/indexers?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search78e216af.search.windows.net/$metadata#indexers/$entity","@odata.etag":"\"0x8D96CBA5C888158\"","name":"sample-indexer","description":null,"dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '383' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:03:12 GMT - elapsed-time: - - '397' - etag: - - W/"0x8D96CBA5C888158" - expires: - - '-1' - location: - - https://search78e216af.search.windows.net/indexers('sample-indexer')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 7949c351-0a96-11ec-ab97-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://search78e216af.search.windows.net/indexers('sample-indexer')/search.status?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://search78e216af.search.windows.net/$metadata#Microsoft.Azure.Search.V2021_04_30_Preview.IndexerExecutionInfo","name":"sample-indexer","status":"running","lastResult":null,"executionHistory":[],"limits":{"maxRunTime":"PT0S","maxDocumentExtractionSize":0,"maxDocumentContentCharactersToExtract":0},"currentState":{"mode":"indexingAllDocs","allDocsInitialTrackingState":null,"allDocsFinalTrackingState":null,"resetDocsInitialTrackingState":null,"resetDocsFinalTrackingState":null,"resetDocumentKeys":[]}}' - headers: - cache-control: - - no-cache - content-length: - - '527' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:03:12 GMT - elapsed-time: - - '18' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 79b4c51f-0a96-11ec-97b8-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_list_indexer.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_list_indexer.yaml deleted file mode 100644 index 9ea075cd5f14..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_list_indexer.yaml +++ /dev/null @@ -1,352 +0,0 @@ -interactions: -- request: - body: '{"name": "sample-datasource", "type": "azureblob", "credentials": {"connectionString": - "connection_string"}, "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '325' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchf8231428.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchf8231428.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CBA662F3622\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '407' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:03:28 GMT - elapsed-time: - - '41' - etag: - - W/"0x8D96CBA662F3622" - expires: - - '-1' - location: - - https://searchf8231428.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 831f6317-0a96-11ec-bb5b-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "hotels", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '128' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchf8231428.search.windows.net/indexes?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchf8231428.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CBA66C46436\"","name":"hotels","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}],"scoringProfiles":[],"corsOptions":null,"suggesters":[],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '664' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:03:29 GMT - elapsed-time: - - '665' - etag: - - W/"0x8D96CBA66C46436" - expires: - - '-1' - location: - - https://searchf8231428.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 8347ef12-0a96-11ec-aebc-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "another-datasource", "type": "azureblob", "credentials": {"connectionString": - "connection_string"}, "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '326' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchf8231428.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchf8231428.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CBA66F9FC81\"","name":"another-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '408' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:03:29 GMT - elapsed-time: - - '130' - etag: - - W/"0x8D96CBA66F9FC81" - expires: - - '-1' - location: - - https://searchf8231428.search.windows.net/datasources('another-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 83dd7857-0a96-11ec-b1f2-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "another-index", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '135' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchf8231428.search.windows.net/indexes?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchf8231428.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CBA6769E8D0\"","name":"another-index","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}],"scoringProfiles":[],"corsOptions":null,"suggesters":[],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '671' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:03:30 GMT - elapsed-time: - - '493' - etag: - - W/"0x8D96CBA6769E8D0" - expires: - - '-1' - location: - - https://searchf8231428.search.windows.net/indexes('another-index')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 84136e66-0a96-11ec-a221-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "sample-indexer", "dataSourceName": "sample-datasource", "targetIndexName": - "hotels", "disabled": false}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '113' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchf8231428.search.windows.net/indexers?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchf8231428.search.windows.net/$metadata#indexers/$entity","@odata.etag":"\"0x8D96CBA6863416F\"","name":"sample-indexer","description":null,"dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '383' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:03:32 GMT - elapsed-time: - - '1561' - etag: - - W/"0x8D96CBA6863416F" - expires: - - '-1' - location: - - https://searchf8231428.search.windows.net/indexers('sample-indexer')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 84823fbe-0a96-11ec-911b-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "another-indexer", "dataSourceName": "another-datasource", "targetIndexName": - "another-index", "disabled": false}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '122' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchf8231428.search.windows.net/indexers?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchf8231428.search.windows.net/$metadata#indexers/$entity","@odata.etag":"\"0x8D96CBA68A5FB5B\"","name":"another-indexer","description":null,"dataSourceName":"another-datasource","skillsetName":null,"targetIndexName":"another-index","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '392' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:03:32 GMT - elapsed-time: - - '354' - etag: - - W/"0x8D96CBA68A5FB5B" - expires: - - '-1' - location: - - https://searchf8231428.search.windows.net/indexers('another-indexer')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 8590d141-0a96-11ec-af37-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchf8231428.search.windows.net/indexers?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchf8231428.search.windows.net/$metadata#indexers","value":[{"@odata.etag":"\"0x8D96CBA68A5FB5B\"","name":"another-indexer","description":null,"dataSourceName":"another-datasource","skillsetName":null,"targetIndexName":"another-index","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null},{"@odata.etag":"\"0x8D96CBA6863416F\"","name":"sample-indexer","description":null,"dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '692' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:03:32 GMT - elapsed-time: - - '25' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 85cf9e78-0a96-11ec-8b23-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_reset_indexer.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_reset_indexer.yaml deleted file mode 100644 index f3213206bdc9..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_reset_indexer.yaml +++ /dev/null @@ -1,279 +0,0 @@ -interactions: -- request: - body: '{"name": "sample-datasource", "type": "azureblob", "credentials": {"connectionString": - "connection_string"}, "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '325' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchca8148f.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchca8148f.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CBA71AF9163\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '406' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:03:47 GMT - elapsed-time: - - '50' - etag: - - W/"0x8D96CBA71AF9163" - expires: - - '-1' - location: - - https://searchca8148f.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 8e8efbd5-0a96-11ec-a5b2-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "hotels", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '128' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchca8148f.search.windows.net/indexes?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchca8148f.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CBA724A65C9\"","name":"hotels","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}],"scoringProfiles":[],"corsOptions":null,"suggesters":[],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '663' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:03:48 GMT - elapsed-time: - - '782' - etag: - - W/"0x8D96CBA724A65C9" - expires: - - '-1' - location: - - https://searchca8148f.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 8ec89a35-0a96-11ec-9561-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "sample-indexer", "dataSourceName": "sample-datasource", "targetIndexName": - "hotels", "disabled": false}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '113' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchca8148f.search.windows.net/indexers?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchca8148f.search.windows.net/$metadata#indexers/$entity","@odata.etag":"\"0x8D96CBA729F243F\"","name":"sample-indexer","description":null,"dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '382' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:03:49 GMT - elapsed-time: - - '481' - etag: - - W/"0x8D96CBA729F243F" - expires: - - '-1' - location: - - https://searchca8148f.search.windows.net/indexers('sample-indexer')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 8f632b18-0a96-11ec-8775-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchca8148f.search.windows.net/indexers?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchca8148f.search.windows.net/$metadata#indexers","value":[{"@odata.etag":"\"0x8D96CBA729F243F\"","name":"sample-indexer","description":null,"dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '386' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:03:49 GMT - elapsed-time: - - '11' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 8fd3f80e-0a96-11ec-bba4-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '0' - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searchca8148f.search.windows.net/indexers('sample-indexer')/search.reset?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - date: - - Tue, 31 Aug 2021 20:03:49 GMT - elapsed-time: - - '425' - expires: - - '-1' - pragma: - - no-cache - request-id: - - 8fddb974-0a96-11ec-8b69-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 204 - message: No Content -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searchca8148f.search.windows.net/indexers('sample-indexer')/search.status?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searchca8148f.search.windows.net/$metadata#Microsoft.Azure.Search.V2021_04_30_Preview.IndexerExecutionInfo","name":"sample-indexer","status":"running","lastResult":{"status":"inProgress","statusDetail":null,"errorMessage":null,"startTime":"2021-08-31T20:03:49.986Z","endTime":null,"itemsProcessed":0,"itemsFailed":0,"initialTrackingState":null,"finalTrackingState":null,"mode":"indexingAllDocs","errors":[],"warnings":[],"metrics":null},"executionHistory":[{"status":"reset","statusDetail":null,"errorMessage":null,"startTime":"2021-08-31T20:03:49.565Z","endTime":"2021-08-31T20:03:49.565Z","itemsProcessed":0,"itemsFailed":0,"initialTrackingState":null,"finalTrackingState":null,"mode":"indexingAllDocs","errors":[],"warnings":[],"metrics":null}],"limits":{"maxRunTime":"PT2M","maxDocumentExtractionSize":16777216,"maxDocumentContentCharactersToExtract":32768},"currentState":{"mode":"indexingAllDocs","allDocsInitialTrackingState":null,"allDocsFinalTrackingState":null,"resetDocsInitialTrackingState":null,"resetDocsFinalTrackingState":null,"resetDocumentKeys":[]}}' - headers: - cache-control: - - no-cache - content-length: - - '1094' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:03:49 GMT - elapsed-time: - - '48' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 9026e460-0a96-11ec-a63e-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_run_indexer.yaml b/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_run_indexer.yaml deleted file mode 100644 index bb9dcfe190fa..000000000000 --- a/sdk/search/azure-search-documents/tests/recordings/test_search_indexer_client_live.test_run_indexer.yaml +++ /dev/null @@ -1,281 +0,0 @@ -interactions: -- request: - body: '{"name": "sample-datasource", "type": "azureblob", "credentials": {"connectionString": - "connection_string"}, "container": {"name": "searchcontainer"}}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '325' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searche43613c1.search.windows.net/datasources?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searche43613c1.search.windows.net/$metadata#datasources/$entity","@odata.etag":"\"0x8D96CBA7BB6513B\"","name":"sample-datasource","description":null,"type":"azureblob","subtype":null,"credentials":{"connectionString":null},"container":{"name":"searchcontainer","query":null},"dataChangeDetectionPolicy":null,"dataDeletionDetectionPolicy":null,"encryptionKey":null,"identity":null}' - headers: - cache-control: - - no-cache - content-length: - - '407' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:04:04 GMT - elapsed-time: - - '47' - etag: - - W/"0x8D96CBA7BB6513B" - expires: - - '-1' - location: - - https://searche43613c1.search.windows.net/datasources('sample-datasource')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 989b728d-0a96-11ec-9967-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "hotels", "fields": [{"name": "hotelId", "type": "Edm.String", - "key": true, "retrievable": true, "searchable": false}]}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '128' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searche43613c1.search.windows.net/indexes?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searche43613c1.search.windows.net/$metadata#indexes/$entity","@odata.etag":"\"0x8D96CBA7C525E54\"","name":"hotels","defaultScoringProfile":null,"fields":[{"name":"hotelId","type":"Edm.String","searchable":false,"filterable":true,"retrievable":true,"sortable":true,"facetable":true,"key":true,"indexAnalyzer":null,"searchAnalyzer":null,"analyzer":null,"normalizer":null,"synonymMaps":[]}],"scoringProfiles":[],"corsOptions":null,"suggesters":[],"analyzers":[],"normalizers":[],"tokenizers":[],"tokenFilters":[],"charFilters":[],"encryptionKey":null,"similarity":{"@odata.type":"#Microsoft.Azure.Search.BM25Similarity","k1":null,"b":null}}' - headers: - cache-control: - - no-cache - content-length: - - '664' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:04:05 GMT - elapsed-time: - - '828' - etag: - - W/"0x8D96CBA7C525E54" - expires: - - '-1' - location: - - https://searche43613c1.search.windows.net/indexes('hotels')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 98ceaa28-0a96-11ec-aeac-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: '{"name": "sample-indexer", "dataSourceName": "sample-datasource", "targetIndexName": - "hotels", "disabled": false}' - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '113' - Content-Type: - - application/json - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searche43613c1.search.windows.net/indexers?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searche43613c1.search.windows.net/$metadata#indexers/$entity","@odata.etag":"\"0x8D96CBA7CA5BCFA\"","name":"sample-indexer","description":null,"dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}' - headers: - cache-control: - - no-cache - content-length: - - '383' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:04:05 GMT - elapsed-time: - - '588' - etag: - - W/"0x8D96CBA7CA5BCFA" - expires: - - '-1' - location: - - https://searche43613c1.search.windows.net/indexers('sample-indexer')?api-version=2021-04-30-Preview - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 996d0aa6-0a96-11ec-b3f3-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 201 - message: Created -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searche43613c1.search.windows.net/indexers?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searche43613c1.search.windows.net/$metadata#indexers","value":[{"@odata.etag":"\"0x8D96CBA7CA5BCFA\"","name":"sample-indexer","description":null,"dataSourceName":"sample-datasource","skillsetName":null,"targetIndexName":"hotels","disabled":false,"schedule":null,"parameters":null,"fieldMappings":[],"outputFieldMappings":[],"cache":null,"encryptionKey":null}]}' - headers: - cache-control: - - no-cache - content-length: - - '387' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:04:05 GMT - elapsed-time: - - '20' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 99e8d0e6-0a96-11ec-a5d9-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - Content-Length: - - '0' - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: POST - uri: https://searche43613c1.search.windows.net/indexers('sample-indexer')/search.run?api-version=2021-04-30-Preview - response: - body: - string: '' - headers: - cache-control: - - no-cache - content-length: - - '0' - date: - - Tue, 31 Aug 2021 20:04:05 GMT - elapsed-time: - - '57' - expires: - - '-1' - pragma: - - no-cache - request-id: - - 99f43f83-0a96-11ec-a830-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - status: - code: 202 - message: Accepted -- request: - body: null - headers: - Accept: - - application/json;odata.metadata=minimal - Accept-Encoding: - - gzip, deflate - Connection: - - keep-alive - User-Agent: - - azsdk-python-search-documents/11.3.0b3 Python/3.9.2 (Windows-10-10.0.19041-SP0) - method: GET - uri: https://searche43613c1.search.windows.net/indexers('sample-indexer')/search.status?api-version=2021-04-30-Preview - response: - body: - string: '{"@odata.context":"https://searche43613c1.search.windows.net/$metadata#Microsoft.Azure.Search.V2021_04_30_Preview.IndexerExecutionInfo","name":"sample-indexer","status":"running","lastResult":null,"executionHistory":[],"limits":{"maxRunTime":"PT0S","maxDocumentExtractionSize":0,"maxDocumentContentCharactersToExtract":0},"currentState":{"mode":"indexingAllDocs","allDocsInitialTrackingState":null,"allDocsFinalTrackingState":null,"resetDocsInitialTrackingState":null,"resetDocsFinalTrackingState":null,"resetDocumentKeys":[]}}' - headers: - cache-control: - - no-cache - content-length: - - '527' - content-type: - - application/json; odata.metadata=minimal - date: - - Tue, 31 Aug 2021 20:04:05 GMT - elapsed-time: - - '25' - expires: - - '-1' - odata-version: - - '4.0' - pragma: - - no-cache - preference-applied: - - odata.include-annotations="*" - request-id: - - 9a05ee1f-0a96-11ec-96fc-74c63bed1137 - strict-transport-security: - - max-age=15724800; includeSubDomains - vary: - - Accept-Encoding - status: - code: 200 - message: OK -version: 1 diff --git a/sdk/search/azure-search-documents/tests/search_service_preparer.py b/sdk/search/azure-search-documents/tests/search_service_preparer.py index ada16aafc06c..8077779be885 100644 --- a/sdk/search/azure-search-documents/tests/search_service_preparer.py +++ b/sdk/search/azure-search-documents/tests/search_service_preparer.py @@ -3,25 +3,610 @@ # Licensed under the MIT License. # ------------------------------------ -import datetime -from os.path import dirname, realpath -import time - -try: - from unittest.mock import Mock -except ImportError: # python < 3.3 - from mock import Mock +import functools +from os import environ +from os.path import dirname, realpath, join +import inspect import json import requests +import wrapt -from devtools_testutils import AzureMgmtPreparer, ResourceGroupPreparer -from devtools_testutils.resource_testcase import RESOURCE_GROUP_PARAM +from devtools_testutils import EnvironmentVariableLoader from azure_devtools.scenario_tests.exceptions import AzureTestError +from azure.core.credentials import AzureKeyCredential +from azure.core.exceptions import ResourceNotFoundError + + SERVICE_URL_FMT = "https://{}.search.windows.net/indexes?api-version=2021-04-30-Preview" TIME_TO_SLEEP = 3 + +SearchEnvVarPreparer = functools.partial( + EnvironmentVariableLoader, + "search", + search_service_endpoint="https://fakesearchendpoint.search.windows.net", + search_service_api_key="fakesearchapikey", + search_service_name="fakesearchendpoint", + search_query_api_key="fakequeryapikey", + search_storage_connection_string="DefaultEndpointsProtocol=https;AccountName=fakestoragecs;AccountKey=FAKE;EndpointSuffix=core.windows.net", + search_storage_container_name="fakestoragecontainer" +) + +def _load_schema(filename): + if not filename: + return None + cwd = dirname(realpath(__file__)) + return open(join(cwd, filename)).read() + +def _load_batch(filename): + if not filename: + return None + cwd = dirname(realpath(__file__)) + try: + return json.load(open(join(cwd, filename))) + except UnicodeDecodeError: + return json.load(open(join(cwd, filename), encoding='utf-8')) + +def _clean_up_indexes(endpoint, api_key): + from azure.search.documents.indexes import SearchIndexClient + client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + + # wipe the synonym maps which seem to survive the index + for map in client.get_synonym_maps(): + client.delete_synonym_map(map.name) + + # wipe any existing indexes + for index in client.list_indexes(): + client.delete_index(index) + + +def _clean_up_indexers(endpoint, api_key): + from azure.search.documents.indexes import SearchIndexerClient + client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) + for indexer in client.get_indexers(): + client.delete_indexer(indexer) + for datasource in client.get_data_source_connection_names(): + client.delete_data_source_connection(datasource) + for skillset in client.get_skillset_names(): + client.delete_skillset(skillset) + +def _set_up_index(service_name, endpoint, api_key, schema, index_batch): + from azure.core.credentials import AzureKeyCredential + from azure.search.documents import SearchClient + from azure.search.documents._generated.models import IndexBatch + + schema = _load_schema(schema) + index_batch = _load_batch(index_batch) + if schema: + index_name = json.loads(schema)["name"] + response = requests.post( + SERVICE_URL_FMT.format(service_name), + headers={"Content-Type": "application/json", "api-key": api_key}, + data=schema, + ) + if response.status_code != 201: + raise AzureTestError( + "Could not create a search index {}".format(response.status_code) + ) + + # optionally load data into the index + if index_batch and schema: + batch = IndexBatch.deserialize(index_batch) + index_client = SearchClient(endpoint, index_name, AzureKeyCredential(api_key)) + results = index_client.index_documents(batch) + if not all(result.succeeded for result in results): + raise AzureTestError("Document upload to search index failed") + + # Indexing is asynchronous, so if you get a 200 from the REST API, that only means that the documents are + # persisted, not that they're searchable yet. The only way to check for searchability is to run queries, + # and even then things are eventually consistent due to replication. In the Track 1 SDK tests, we "solved" + # this by using a constant delay between indexing and querying. + import time + time.sleep(TIME_TO_SLEEP) + + +def _trim_kwargs_from_test_function(fn, kwargs): + # the next function is the actual test function. the kwargs need to be trimmed so + # that parameters which are not required will not be passed to it. + if not getattr(fn, "__is_preparer", False): + try: + args, _, kw, _, _, _, _ = inspect.getfullargspec(fn) + except AttributeError: + args, _, kw, _ = inspect.getargspec(fn) # pylint: disable=deprecated-method + if kw is None: + args = set(args) + for key in [k for k in kwargs if k not in args]: + del kwargs[key] + +def search_decorator(*, schema, index_batch): + + @wrapt.decorator + def wrapper(func, _, args, kwargs): + # set up hotels search index + test = args[0] + api_key = kwargs.get('search_service_api_key') + endpoint = kwargs.get('search_service_endpoint') + service_name = kwargs.get('search_service_name') + if test.is_live: + _clean_up_indexes(endpoint, api_key) + _set_up_index(service_name, endpoint, api_key, schema, index_batch) + _clean_up_indexers(endpoint, api_key) + index_name = json.loads(_load_schema(schema))['name'] if schema else None + index_batch_data = _load_batch(index_batch) if index_batch else None + + # ensure that the names in the test signatures are in the + # bag of kwargs + kwargs['endpoint'] = endpoint + kwargs['api_key'] = AzureKeyCredential(api_key) + kwargs['index_name'] = index_name + kwargs['index_batch'] = index_batch_data + + trimmed_kwargs = {k: v for k, v in kwargs.items()} + _trim_kwargs_from_test_function(func, trimmed_kwargs) + + return func(*args, **trimmed_kwargs) + return wrapper + +# FIXME: DELETE EVERYTHING AFTER THIS LINE BEFORE MERGING + +from devtools_testutils import ResourceGroupPreparer, AzureMgmtPreparer +from devtools_testutils.resource_testcase import RESOURCE_GROUP_PARAM +import datetime + + +# TODO: Remove this +class SearchResourceGroupPreparer(ResourceGroupPreparer): + def create_resource(self, name, **kwargs): + result = super(SearchResourceGroupPreparer, self).create_resource(name, **kwargs) + if self.is_live and self._need_creation: + expiry = datetime.datetime.now() + datetime.timedelta(days=1) + resource_group_params = dict(tags={'DeleteAfter': expiry.isoformat()}, location=self.location) + self.client.resource_groups.create_or_update(name, resource_group_params) + return result + +#TODO: Remove this +class SearchServicePreparer(AzureMgmtPreparer): + def __init__( + self, + schema=None, + index_batch=None, + name_prefix="search", + resource_group_parameter_name=RESOURCE_GROUP_PARAM, + disable_recording=True, + playback_fake_resource=None, + client_kwargs=None, + ): + super(SearchServicePreparer, self).__init__( + name_prefix, + random_name_length=24, + disable_recording=disable_recording, + playback_fake_resource=playback_fake_resource, + client_kwargs=client_kwargs, + ) + self.resource_group_parameter_name = resource_group_parameter_name + self.schema = schema + self.index_name = None + self.index_batch = index_batch + self.service_name = "TEST-SERVICE-NAME" + + def _get_resource_group(self, **kwargs): + try: + return kwargs[self.resource_group_parameter_name] + except KeyError: + template = ( + "To create a search service a resource group is required. Please add " + "decorator @{} in front of this preparer." + ) + raise AzureTestError(template.format(ResourceGroupPreparer.__name__)) + + def create_resource(self, name, **kwargs): + if self.schema: + schema = json.loads(self.schema) + else: + schema = None + self.service_name = self.create_random_name() + self.endpoint = "https://{}.search.windows.net".format(self.service_name) + + if not self.is_live: + return { + "api_key": "api-key", + "index_name": schema["name"] if schema else None, + "endpoint": self.endpoint, + } + + group_name = self._get_resource_group(**kwargs).name + + from azure.mgmt.search import SearchManagementClient + from azure.mgmt.search.models import ProvisioningState + + self.mgmt_client = self.create_mgmt_client(SearchManagementClient) + + # create the search service + from azure.mgmt.search.models import SearchService, Sku + + service_config = SearchService(location="West US", sku=Sku(name="basic")) + resource = self.mgmt_client.services.begin_create_or_update( + group_name, self.service_name, service_config + ) + + retries = 4 + for i in range(retries): + try: + result = resource.result() + if result.provisioning_state == ProvisioningState.succeeded: + break + except Exception as ex: + if i == retries - 1: + raise + time.sleep(TIME_TO_SLEEP) + time.sleep(TIME_TO_SLEEP) + + # note the for/else here: will raise an error if we *don't* break + # above i.e. if result.provisioning state was never "Succeeded" + else: + raise AzureTestError("Could not create a search service") + + api_key = self.mgmt_client.admin_keys.get( + group_name, self.service_name + ).primary_key + + if self.schema: + response = requests.post( + SERVICE_URL_FMT.format(self.service_name), + headers={"Content-Type": "application/json", "api-key": api_key}, + data=self.schema, + ) + if response.status_code != 201: + raise AzureTestError( + "Could not create a search index {}".format(response.status_code) + ) + self.index_name = schema["name"] + + # optionally load data into the index + if self.index_batch and self.schema: + from azure.core.credentials import AzureKeyCredential + from azure.search.documents import SearchClient + from azure.search.documents._generated.models import IndexBatch + + batch = IndexBatch.deserialize(self.index_batch) + index_client = SearchClient( + self.endpoint, self.index_name, AzureKeyCredential(api_key) + ) + results = index_client.index_documents(batch) + if not all(result.succeeded for result in results): + raise AzureTestError("Document upload to search index failed") + + # Indexing is asynchronous, so if you get a 200 from the REST API, that only means that the documents are + # persisted, not that they're searchable yet. The only way to check for searchability is to run queries, + # and even then things are eventually consistent due to replication. In the Track 1 SDK tests, we "solved" + # this by using a constant delay between indexing and querying. + import time + + time.sleep(TIME_TO_SLEEP) + + return { + "api_key": api_key, + "index_name": self.index_name, + "endpoint": self.endpoint, + } + + def remove_resource(self, name, **kwargs): + if not self.is_live: + return + + group_name = self._get_resource_group(**kwargs).name + self.mgmt_client.services.delete(group_name, self.service_name) + +# FIXME: DELETE EVERYTHING AFTER THIS LINE BEFORE MERGING + +from devtools_testutils import ResourceGroupPreparer, AzureMgmtPreparer +from devtools_testutils.resource_testcase import RESOURCE_GROUP_PARAM +import datetime + + +# TODO: Remove this +class SearchResourceGroupPreparer(ResourceGroupPreparer): + def create_resource(self, name, **kwargs): + result = super(SearchResourceGroupPreparer, self).create_resource(name, **kwargs) + if self.is_live and self._need_creation: + expiry = datetime.datetime.now() + datetime.timedelta(days=1) + resource_group_params = dict(tags={'DeleteAfter': expiry.isoformat()}, location=self.location) + self.client.resource_groups.create_or_update(name, resource_group_params) + return result + +#TODO: Remove this +class SearchServicePreparer(AzureMgmtPreparer): + def __init__( + self, + schema=None, + index_batch=None, + name_prefix="search", + resource_group_parameter_name=RESOURCE_GROUP_PARAM, + disable_recording=True, + playback_fake_resource=None, + client_kwargs=None, + ): + super(SearchServicePreparer, self).__init__( + name_prefix, + random_name_length=24, + disable_recording=disable_recording, + playback_fake_resource=playback_fake_resource, + client_kwargs=client_kwargs, + ) + self.resource_group_parameter_name = resource_group_parameter_name + self.schema = schema + self.index_name = None + self.index_batch = index_batch + self.service_name = "TEST-SERVICE-NAME" + + def _get_resource_group(self, **kwargs): + try: + return kwargs[self.resource_group_parameter_name] + except KeyError: + template = ( + "To create a search service a resource group is required. Please add " + "decorator @{} in front of this preparer." + ) + raise AzureTestError(template.format(ResourceGroupPreparer.__name__)) + + def create_resource(self, name, **kwargs): + if self.schema: + schema = json.loads(self.schema) + else: + schema = None + self.service_name = self.create_random_name() + self.endpoint = "https://{}.search.windows.net".format(self.service_name) + + if not self.is_live: + return { + "api_key": "api-key", + "index_name": schema["name"] if schema else None, + "endpoint": self.endpoint, + } + + group_name = self._get_resource_group(**kwargs).name + + from azure.mgmt.search import SearchManagementClient + from azure.mgmt.search.models import ProvisioningState + + self.mgmt_client = self.create_mgmt_client(SearchManagementClient) + + # create the search service + from azure.mgmt.search.models import SearchService, Sku + + service_config = SearchService(location="West US", sku=Sku(name="basic")) + resource = self.mgmt_client.services.begin_create_or_update( + group_name, self.service_name, service_config + ) + + retries = 4 + for i in range(retries): + try: + result = resource.result() + if result.provisioning_state == ProvisioningState.succeeded: + break + except Exception as ex: + if i == retries - 1: + raise + time.sleep(TIME_TO_SLEEP) + time.sleep(TIME_TO_SLEEP) + + # note the for/else here: will raise an error if we *don't* break + # above i.e. if result.provisioning state was never "Succeeded" + else: + raise AzureTestError("Could not create a search service") + + api_key = self.mgmt_client.admin_keys.get( + group_name, self.service_name + ).primary_key + + if self.schema: + response = requests.post( + SERVICE_URL_FMT.format(self.service_name), + headers={"Content-Type": "application/json", "api-key": api_key}, + data=self.schema, + ) + if response.status_code != 201: + raise AzureTestError( + "Could not create a search index {}".format(response.status_code) + ) + self.index_name = schema["name"] + + # optionally load data into the index + if self.index_batch and self.schema: + from azure.core.credentials import AzureKeyCredential + from azure.search.documents import SearchClient + from azure.search.documents._generated.models import IndexBatch + + batch = IndexBatch.deserialize(self.index_batch) + index_client = SearchClient( + self.endpoint, self.index_name, AzureKeyCredential(api_key) + ) + results = index_client.index_documents(batch) + if not all(result.succeeded for result in results): + raise AzureTestError("Document upload to search index failed") + + # Indexing is asynchronous, so if you get a 200 from the REST API, that only means that the documents are + # persisted, not that they're searchable yet. The only way to check for searchability is to run queries, + # and even then things are eventually consistent due to replication. In the Track 1 SDK tests, we "solved" + # this by using a constant delay between indexing and querying. + import time + + time.sleep(TIME_TO_SLEEP) + + return { + "api_key": api_key, + "index_name": self.index_name, + "endpoint": self.endpoint, + } + + def remove_resource(self, name, **kwargs): + if not self.is_live: + return + + group_name = self._get_resource_group(**kwargs).name + self.mgmt_client.services.delete(group_name, self.service_name) + +# FIXME: DELETE EVERYTHING AFTER THIS LINE BEFORE MERGING + +from devtools_testutils import ResourceGroupPreparer, AzureMgmtPreparer +from devtools_testutils.resource_testcase import RESOURCE_GROUP_PARAM +import datetime + + +# TODO: Remove this +class SearchResourceGroupPreparer(ResourceGroupPreparer): + def create_resource(self, name, **kwargs): + result = super(SearchResourceGroupPreparer, self).create_resource(name, **kwargs) + if self.is_live and self._need_creation: + expiry = datetime.datetime.now() + datetime.timedelta(days=1) + resource_group_params = dict(tags={'DeleteAfter': expiry.isoformat()}, location=self.location) + self.client.resource_groups.create_or_update(name, resource_group_params) + return result + +#TODO: Remove this +class SearchServicePreparer(AzureMgmtPreparer): + def __init__( + self, + schema=None, + index_batch=None, + name_prefix="search", + resource_group_parameter_name=RESOURCE_GROUP_PARAM, + disable_recording=True, + playback_fake_resource=None, + client_kwargs=None, + ): + super(SearchServicePreparer, self).__init__( + name_prefix, + random_name_length=24, + disable_recording=disable_recording, + playback_fake_resource=playback_fake_resource, + client_kwargs=client_kwargs, + ) + self.resource_group_parameter_name = resource_group_parameter_name + self.schema = schema + self.index_name = None + self.index_batch = index_batch + self.service_name = "TEST-SERVICE-NAME" + + def _get_resource_group(self, **kwargs): + try: + return kwargs[self.resource_group_parameter_name] + except KeyError: + template = ( + "To create a search service a resource group is required. Please add " + "decorator @{} in front of this preparer." + ) + raise AzureTestError(template.format(ResourceGroupPreparer.__name__)) + + def create_resource(self, name, **kwargs): + if self.schema: + schema = json.loads(self.schema) + else: + schema = None + self.service_name = self.create_random_name() + self.endpoint = "https://{}.search.windows.net".format(self.service_name) + + if not self.is_live: + return { + "api_key": "api-key", + "index_name": schema["name"] if schema else None, + "endpoint": self.endpoint, + } + + group_name = self._get_resource_group(**kwargs).name + + from azure.mgmt.search import SearchManagementClient + from azure.mgmt.search.models import ProvisioningState + + self.mgmt_client = self.create_mgmt_client(SearchManagementClient) + + # create the search service + from azure.mgmt.search.models import SearchService, Sku + + service_config = SearchService(location="West US", sku=Sku(name="basic")) + resource = self.mgmt_client.services.begin_create_or_update( + group_name, self.service_name, service_config + ) + + retries = 4 + for i in range(retries): + try: + result = resource.result() + if result.provisioning_state == ProvisioningState.succeeded: + break + except Exception as ex: + if i == retries - 1: + raise + time.sleep(TIME_TO_SLEEP) + time.sleep(TIME_TO_SLEEP) + + # note the for/else here: will raise an error if we *don't* break + # above i.e. if result.provisioning state was never "Succeeded" + else: + raise AzureTestError("Could not create a search service") + + api_key = self.mgmt_client.admin_keys.get( + group_name, self.service_name + ).primary_key + + if self.schema: + response = requests.post( + SERVICE_URL_FMT.format(self.service_name), + headers={"Content-Type": "application/json", "api-key": api_key}, + data=self.schema, + ) + if response.status_code != 201: + raise AzureTestError( + "Could not create a search index {}".format(response.status_code) + ) + self.index_name = schema["name"] + + # optionally load data into the index + if self.index_batch and self.schema: + from azure.core.credentials import AzureKeyCredential + from azure.search.documents import SearchClient + from azure.search.documents._generated.models import IndexBatch + + batch = IndexBatch.deserialize(self.index_batch) + index_client = SearchClient( + self.endpoint, self.index_name, AzureKeyCredential(api_key) + ) + results = index_client.index_documents(batch) + if not all(result.succeeded for result in results): + raise AzureTestError("Document upload to search index failed") + + # Indexing is asynchronous, so if you get a 200 from the REST API, that only means that the documents are + # persisted, not that they're searchable yet. The only way to check for searchability is to run queries, + # and even then things are eventually consistent due to replication. In the Track 1 SDK tests, we "solved" + # this by using a constant delay between indexing and querying. + import time + + time.sleep(TIME_TO_SLEEP) + + return { + "api_key": api_key, + "index_name": self.index_name, + "endpoint": self.endpoint, + } + + def remove_resource(self, name, **kwargs): + if not self.is_live: + return + + group_name = self._get_resource_group(**kwargs).name + self.mgmt_client.services.delete(group_name, self.service_name) + +# FIXME: DELETE EVERYTHING AFTER THIS LINE BEFORE MERGING + +from devtools_testutils import ResourceGroupPreparer, AzureMgmtPreparer +from devtools_testutils.resource_testcase import RESOURCE_GROUP_PARAM +import datetime + + +# TODO: Remove this class SearchResourceGroupPreparer(ResourceGroupPreparer): def create_resource(self, name, **kwargs): result = super(SearchResourceGroupPreparer, self).create_resource(name, **kwargs) @@ -31,6 +616,7 @@ def create_resource(self, name, **kwargs): self.client.resource_groups.create_or_update(name, resource_group_params) return result +#TODO: Remove this class SearchServicePreparer(AzureMgmtPreparer): def __init__( self, diff --git a/sdk/search/azure-search-documents/tests/test_search_client_basic_live.py b/sdk/search/azure-search-documents/tests/test_search_client_basic_live.py index 5749a274ef05..cff2ce8c78ed 100644 --- a/sdk/search/azure-search-documents/tests/test_search_client_basic_live.py +++ b/sdk/search/azure-search-documents/tests/test_search_client_basic_live.py @@ -3,59 +3,40 @@ # Licensed under the MIT License. See License.txt in the project root for # license information. # -------------------------------------------------------------------------- -import json -from os.path import dirname, join, realpath -import time import pytest -from devtools_testutils import AzureMgmtTestCase, ResourceGroupPreparer -from azure_devtools.scenario_tests import ReplayableTest - -from search_service_preparer import SearchServicePreparer - -CWD = dirname(realpath(__file__)) - -SCHEMA = open(join(CWD, "hotel_schema.json")).read() -try: - BATCH = json.load(open(join(CWD, "hotel_small.json"))) -except UnicodeDecodeError: - BATCH = json.load(open(join(CWD, "hotel_small.json"), encoding='utf-8')) from azure.core.exceptions import HttpResponseError -from azure.core.credentials import AzureKeyCredential from azure.search.documents import SearchClient +from devtools_testutils import AzureRecordedTestCase, recorded_by_proxy -TIME_TO_SLEEP = 3 +from search_service_preparer import SearchEnvVarPreparer, search_decorator -class SearchClientTest(AzureMgmtTestCase): - FILTER_HEADERS = ReplayableTest.FILTER_HEADERS + ['api-key'] +class TestSearchClient(AzureRecordedTestCase): - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_document_count(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy + def test_get_document_count(self, endpoint, api_key, index_name): + client = SearchClient(endpoint, index_name, api_key) assert client.get_document_count() == 10 - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_document(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy + def test_get_document(self, endpoint, api_key, index_name, index_batch): + client = SearchClient(endpoint, index_name, api_key) for hotel_id in range(1, 11): result = client.get_document(key=str(hotel_id)) - expected = BATCH["value"][hotel_id - 1] + expected = index_batch["value"][hotel_id - 1] assert result.get("hotelId") == expected.get("hotelId") assert result.get("hotelName") == expected.get("hotelName") assert result.get("description") == expected.get("description") - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_document_missing(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy + def test_get_document_missing(self, endpoint, api_key, index_name): + client = SearchClient(endpoint, index_name, api_key) with pytest.raises(HttpResponseError): client.get_document(key="1000") diff --git a/sdk/search/azure-search-documents/tests/test_search_client_buffered_sender_live.py b/sdk/search/azure-search-documents/tests/test_search_client_buffered_sender_live.py index 6f722eece6c3..103486964078 100644 --- a/sdk/search/azure-search-documents/tests/test_search_client_buffered_sender_live.py +++ b/sdk/search/azure-search-documents/tests/test_search_client_buffered_sender_live.py @@ -3,213 +3,167 @@ # Licensed under the MIT License. See License.txt in the project root for # license information. # -------------------------------------------------------------------------- -import json -from os.path import dirname, join, realpath -import time import pytest - -from devtools_testutils import AzureMgmtTestCase, ResourceGroupPreparer -from azure_devtools.scenario_tests import ReplayableTest - -from search_service_preparer import SearchServicePreparer - -CWD = dirname(realpath(__file__)) - -SCHEMA = open(join(CWD, "hotel_schema.json")).read() -try: - BATCH = json.load(open(join(CWD, "hotel_small.json"))) -except UnicodeDecodeError: - BATCH = json.load(open(join(CWD, "hotel_small.json"), encoding='utf-8')) +import time from azure.core.exceptions import HttpResponseError from azure.core.credentials import AzureKeyCredential from azure.search.documents import SearchIndexingBufferedSender, SearchClient +from devtools_testutils import AzureRecordedTestCase, recorded_by_proxy +from search_service_preparer import SearchEnvVarPreparer, search_decorator TIME_TO_SLEEP = 3 -class SearchIndexingBufferedSenderTest(AzureMgmtTestCase): - FILTER_HEADERS = ReplayableTest.FILTER_HEADERS + ['api-key'] - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_upload_documents_new(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - batch_client = SearchIndexingBufferedSender( - endpoint, index_name, AzureKeyCredential(api_key) - ) + +class TestSearchIndexingBufferedSender(AzureRecordedTestCase): + + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy + def test_search_client_index_buffered_sender(self, endpoint, api_key, index_name): + client = SearchClient(endpoint, index_name, api_key) + batch_client = SearchIndexingBufferedSender(endpoint, index_name, api_key) + try: + doc_count = 10 + doc_count = self._test_upload_documents_new(client, batch_client, doc_count) + doc_count = self._test_upload_documents_existing(client, batch_client, doc_count) + doc_count = self._test_delete_documents_existing(client, batch_client, doc_count) + doc_count = self._test_delete_documents_missing(client, batch_client, doc_count) + doc_count = self._test_merge_documents_existing(client, batch_client, doc_count) + doc_count = self._test_merge_documents_missing(client, batch_client, doc_count) + doc_count = self._test_merge_or_upload_documents(client, batch_client, doc_count) + finally: + batch_client.close() + + def _test_upload_documents_new(self, client, batch_client, doc_count): batch_client._batch_action_count = 2 - DOCUMENTS = [ + docs = [ {"hotelId": "1000", "rating": 5, "rooms": [], "hotelName": "Azure Inn"}, {"hotelId": "1001", "rating": 4, "rooms": [], "hotelName": "Redmond Hotel"}, ] - batch_client.upload_documents(DOCUMENTS) + batch_client.upload_documents(docs) + doc_count += 2 # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - assert client.get_document_count() == 12 - for doc in DOCUMENTS: + assert client.get_document_count() == doc_count + for doc in docs: result = client.get_document(key=doc["hotelId"]) assert result["hotelId"] == doc["hotelId"] assert result["hotelName"] == doc["hotelName"] assert result["rating"] == doc["rating"] assert result["rooms"] == doc["rooms"] - batch_client.close() - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_upload_documents_existing(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - batch_client = SearchIndexingBufferedSender( - endpoint, index_name, AzureKeyCredential(api_key) - ) + return doc_count + + def _test_upload_documents_existing(self, client, batch_client, doc_count): batch_client._batch_action_count = 2 - DOCUMENTS = [ - {"hotelId": "1000", "rating": 5, "rooms": [], "hotelName": "Azure Inn"}, + # add one new and one existing + docs = [ + {"hotelId": "1002", "rating": 5, "rooms": [], "hotelName": "Azure Inn"}, {"hotelId": "3", "rating": 4, "rooms": [], "hotelName": "Redmond Hotel"}, ] - batch_client.upload_documents(DOCUMENTS) + batch_client.upload_documents(docs) + doc_count += 1 # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - assert client.get_document_count() == 11 - batch_client.close() - + assert client.get_document_count() == doc_count + return doc_count - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_delete_documents_existing(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - batch_client = SearchIndexingBufferedSender( - endpoint, index_name, AzureKeyCredential(api_key) - ) + def _test_delete_documents_existing(self, client, batch_client, doc_count): batch_client._batch_action_count = 2 - batch_client.delete_documents([{"hotelId": "3"}, {"hotelId": "4"}]) - batch_client.close() + docs = [{"hotelId": "3"}, {"hotelId": "4"}] + batch_client.delete_documents(docs) + doc_count -= 2 # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - assert client.get_document_count() == 8 + assert client.get_document_count() == doc_count with pytest.raises(HttpResponseError): client.get_document(key="3") with pytest.raises(HttpResponseError): client.get_document(key="4") + return doc_count - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_delete_documents_missing(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - batch_client = SearchIndexingBufferedSender( - endpoint, index_name, AzureKeyCredential(api_key) - ) + def _test_delete_documents_missing(self, client, batch_client, doc_count): batch_client._batch_action_count = 2 - batch_client.delete_documents([{"hotelId": "1000"}, {"hotelId": "4"}]) - batch_client.close() + # delete one existing and one missing + docs = [{"hotelId": "1003"}, {"hotelId": "2"}] + batch_client.delete_documents(docs) + doc_count -= 1 # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - assert client.get_document_count() == 9 - + assert client.get_document_count() == doc_count with pytest.raises(HttpResponseError): - client.get_document(key="1000") - + client.get_document(key="1003") with pytest.raises(HttpResponseError): - client.get_document(key="4") + client.get_document(key="2") + return doc_count - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_merge_documents_existing(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - batch_client = SearchIndexingBufferedSender( - endpoint, index_name, AzureKeyCredential(api_key) - ) + def _test_merge_documents_existing(self, client, batch_client, doc_count): batch_client._batch_action_count = 2 - batch_client.merge_documents( - [{"hotelId": "3", "rating": 1}, {"hotelId": "4", "rating": 2}] - ) - batch_client.close() + docs = [{"hotelId": "5", "rating": 1}, {"hotelId": "6", "rating": 2}] + batch_client.merge_documents(docs) # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - assert client.get_document_count() == 10 + assert client.get_document_count() == doc_count - result = client.get_document(key="3") + result = client.get_document(key="5") assert result["rating"] == 1 - result = client.get_document(key="4") + result = client.get_document(key="6") assert result["rating"] == 2 + return doc_count - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_merge_documents_missing(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - batch_client = SearchIndexingBufferedSender( - endpoint, index_name, AzureKeyCredential(api_key) - ) + def _test_merge_documents_missing(self, client, batch_client, doc_count): batch_client._batch_action_count = 2 - batch_client.merge_documents( - [{"hotelId": "1000", "rating": 1}, {"hotelId": "4", "rating": 2}] - ) - batch_client.close() + # merge to one existing and one missing document + docs = [{"hotelId": "1003", "rating": 1}, {"hotelId": "1", "rating": 2}] + batch_client.merge_documents(docs) # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - assert client.get_document_count() == 10 + assert client.get_document_count() == doc_count with pytest.raises(HttpResponseError): - client.get_document(key="1000") + client.get_document(key="1003") - result = client.get_document(key="4") + result = client.get_document(key="1") assert result["rating"] == 2 + return doc_count - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_merge_or_upload_documents(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - batch_client = SearchIndexingBufferedSender( - endpoint, index_name, AzureKeyCredential(api_key) - ) + def _test_merge_or_upload_documents(self, client, batch_client, doc_count): batch_client._batch_action_count = 2 - batch_client.merge_or_upload_documents( - [{"hotelId": "1000", "rating": 1}, {"hotelId": "4", "rating": 2}] - ) - batch_client.close() + # merge to one existing and one missing + docs = [{"hotelId": "1003", "rating": 1}, {"hotelId": "1", "rating": 2}] + batch_client.merge_or_upload_documents(docs) + doc_count += 1 # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - assert client.get_document_count() == 11 + assert client.get_document_count() == doc_count - result = client.get_document(key="1000") + result = client.get_document(key="1003") assert result["rating"] == 1 - result = client.get_document(key="4") + result = client.get_document(key="1") assert result["rating"] == 2 + return doc_count diff --git a/sdk/search/azure-search-documents/tests/test_search_client_index_document_live.py b/sdk/search/azure-search-documents/tests/test_search_client_index_document_live.py index abc9d9e2b048..30ec62567af2 100644 --- a/sdk/search/azure-search-documents/tests/test_search_client_index_document_live.py +++ b/sdk/search/azure-search-documents/tests/test_search_client_index_document_live.py @@ -3,184 +3,165 @@ # Licensed under the MIT License. See License.txt in the project root for # license information. # -------------------------------------------------------------------------- -import json -from os.path import dirname, join, realpath -import time import pytest - -from devtools_testutils import AzureMgmtTestCase, ResourceGroupPreparer -from azure_devtools.scenario_tests import ReplayableTest -from search_service_preparer import SearchServicePreparer - -CWD = dirname(realpath(__file__)) - -SCHEMA = open(join(CWD, "hotel_schema.json")).read() -try: - BATCH = json.load(open(join(CWD, "hotel_small.json"))) -except UnicodeDecodeError: - BATCH = json.load(open(join(CWD, "hotel_small.json"), encoding='utf-8')) +import time from azure.core.exceptions import HttpResponseError -from azure.core.credentials import AzureKeyCredential from azure.search.documents import SearchClient +from devtools_testutils import AzureRecordedTestCase, recorded_by_proxy +from search_service_preparer import SearchEnvVarPreparer, search_decorator TIME_TO_SLEEP = 3 -class SearchClientTest(AzureMgmtTestCase): - FILTER_HEADERS = ReplayableTest.FILTER_HEADERS + ['api-key'] - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_upload_documents_new(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - DOCUMENTS = [ +class TestSearchClientIndexDocument(AzureRecordedTestCase): + + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy + def test_search_client_index_document(self, endpoint, api_key, index_name): + client = SearchClient(endpoint, index_name, api_key) + doc_count = 10 + doc_count = self._test_upload_documents_new(client, doc_count) + doc_count = self._test_upload_documents_existing(client, doc_count) + doc_count = self._test_delete_documents_existing(client, doc_count) + doc_count = self._test_delete_documents_missing(client, doc_count) + doc_count = self._test_merge_documents_existing(client, doc_count) + doc_count = self._test_merge_documents_missing(client, doc_count) + doc_count = self._test_merge_or_upload_documents(client, doc_count) + + def _test_upload_documents_new(self, client, doc_count): + docs = [ {"hotelId": "1000", "rating": 5, "rooms": [], "hotelName": "Azure Inn"}, {"hotelId": "1001", "rating": 4, "rooms": [], "hotelName": "Redmond Hotel"}, ] - results = client.upload_documents(DOCUMENTS) - assert len(results) == 2 + results = client.upload_documents(docs) + assert len(results) == len(docs) assert set(x.status_code for x in results) == {201} + doc_count += len(docs) # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - assert client.get_document_count() == 12 - for doc in DOCUMENTS: + assert client.get_document_count() == doc_count + for doc in docs: result = client.get_document(key=doc["hotelId"]) assert result["hotelId"] == doc["hotelId"] assert result["hotelName"] == doc["hotelName"] assert result["rating"] == doc["rating"] assert result["rooms"] == doc["rooms"] + return doc_count - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_upload_documents_existing(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - DOCUMENTS = [ - {"hotelId": "1000", "rating": 5, "rooms": [], "hotelName": "Azure Inn"}, + def _test_upload_documents_existing(self, client, doc_count): + # add one new and one existing + docs = [ + {"hotelId": "1002", "rating": 5, "rooms": [], "hotelName": "Azure Inn"}, {"hotelId": "3", "rating": 4, "rooms": [], "hotelName": "Redmond Hotel"}, ] - results = client.upload_documents(DOCUMENTS) - assert len(results) == 2 + results = client.upload_documents(docs) + assert len(results) == len(docs) + doc_count += 1 assert set(x.status_code for x in results) == {200, 201} + return doc_count - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_delete_documents_existing(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - results = client.delete_documents([{"hotelId": "3"}, {"hotelId": "4"}]) - assert len(results) == 2 + def _test_delete_documents_existing(self, client, doc_count): + docs = [{"hotelId": "3"}, {"hotelId": "4"}] + results = client.delete_documents(docs) + assert len(results) == len(docs) assert set(x.status_code for x in results) == {200} + doc_count -= len(docs) # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - assert client.get_document_count() == 8 + assert client.get_document_count() == doc_count with pytest.raises(HttpResponseError): client.get_document(key="3") with pytest.raises(HttpResponseError): client.get_document(key="4") + return doc_count - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_delete_documents_missing(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - results = client.delete_documents([{"hotelId": "1000"}, {"hotelId": "4"}]) - assert len(results) == 2 + def _test_delete_documents_missing(self, client, doc_count): + # delete one existing and one missing + docs = [{"hotelId": "1003"}, {"hotelId": "2"}] + results = client.delete_documents(docs) + assert len(results) == len(docs) assert set(x.status_code for x in results) == {200} + doc_count -= 1 # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - assert client.get_document_count() == 9 + assert client.get_document_count() == doc_count with pytest.raises(HttpResponseError): - client.get_document(key="1000") + client.get_document(key="1003") with pytest.raises(HttpResponseError): - client.get_document(key="4") + client.get_document(key="2") + return doc_count - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_merge_documents_existing(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - results = client.merge_documents( - [{"hotelId": "3", "rating": 1}, {"hotelId": "4", "rating": 2}] - ) - assert len(results) == 2 + def _test_merge_documents_existing(self, client, doc_count): + docs = [{"hotelId": "5", "rating": 1}, {"hotelId": "6", "rating": 2}] + results = client.merge_documents(docs) + assert len(results) == len(docs) assert set(x.status_code for x in results) == {200} # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - assert client.get_document_count() == 10 + test = client.get_document_count() + assert client.get_document_count() == doc_count - result = client.get_document(key="3") + result = client.get_document(key="5") assert result["rating"] == 1 - result = client.get_document(key="4") + result = client.get_document(key="6") assert result["rating"] == 2 + return doc_count - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_merge_documents_missing(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - results = client.merge_documents( - [{"hotelId": "1000", "rating": 1}, {"hotelId": "4", "rating": 2}] - ) - assert len(results) == 2 + def _test_merge_documents_missing(self, client, doc_count): + # merge to one existing and one missing document + docs = [{"hotelId": "1003", "rating": 1}, {"hotelId": "1", "rating": 2}] + results = client.merge_documents(docs) + assert len(results) == len(docs) assert set(x.status_code for x in results) == {200, 404} # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - assert client.get_document_count() == 10 + assert client.get_document_count() == doc_count with pytest.raises(HttpResponseError): - client.get_document(key="1000") + client.get_document(key="1003") - result = client.get_document(key="4") + result = client.get_document(key="1") assert result["rating"] == 2 + return doc_count - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_merge_or_upload_documents(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - results = client.merge_or_upload_documents( - [{"hotelId": "1000", "rating": 1}, {"hotelId": "4", "rating": 2}] - ) - assert len(results) == 2 + def _test_merge_or_upload_documents(self, client, doc_count): + # merge to one existing and one missing + docs = [{"hotelId": "1003", "rating": 1}, {"hotelId": "1", "rating": 2}] + results = client.merge_or_upload_documents(docs) + assert len(results) == len(docs) assert set(x.status_code for x in results) == {200, 201} + doc_count += 1 # There can be some lag before a document is searchable if self.is_live: time.sleep(TIME_TO_SLEEP) - assert client.get_document_count() == 11 + assert client.get_document_count() == doc_count - result = client.get_document(key="1000") + result = client.get_document(key="1003") assert result["rating"] == 1 - result = client.get_document(key="4") + result = client.get_document(key="1") assert result["rating"] == 2 + return doc_count diff --git a/sdk/search/azure-search-documents/tests/test_search_client_search_live.py b/sdk/search/azure-search-documents/tests/test_search_client_search_live.py index b5f4faaf412d..7c4a96d7d6d1 100644 --- a/sdk/search/azure-search-documents/tests/test_search_client_search_live.py +++ b/sdk/search/azure-search-documents/tests/test_search_client_search_live.py @@ -3,59 +3,46 @@ # Licensed under the MIT License. See License.txt in the project root for # license information. # -------------------------------------------------------------------------- -import json -from os.path import dirname, join, realpath -from devtools_testutils import AzureMgmtTestCase, ResourceGroupPreparer -from azure_devtools.scenario_tests import ReplayableTest -from search_service_preparer import SearchServicePreparer - -CWD = dirname(realpath(__file__)) - -SCHEMA = open(join(CWD, "hotel_schema.json")).read() -try: - BATCH = json.load(open(join(CWD, "hotel_small.json"))) -except UnicodeDecodeError: - BATCH = json.load(open(join(CWD, "hotel_small.json"), encoding='utf-8')) -from azure.core.credentials import AzureKeyCredential from azure.search.documents import SearchClient - -TIME_TO_SLEEP = 3 - -class SearchClientTest(AzureMgmtTestCase): - FILTER_HEADERS = ReplayableTest.FILTER_HEADERS + ['api-key'] - - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_search_simple(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) +from devtools_testutils import AzureRecordedTestCase, recorded_by_proxy + +from search_service_preparer import SearchEnvVarPreparer, search_decorator + + +class TestSearchClient(AzureRecordedTestCase): + + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy + def test_search_client(self, endpoint, api_key, index_name): + client = SearchClient(endpoint, index_name, api_key) + self._test_get_search_simple(client) + self._test_get_search_simple_with_top(client) + self._test_get_search_filter(client) + self._test_get_search_filter_array(client) + self._test_get_search_counts(client) + self._test_get_search_coverage(client) + self._test_get_search_facets_none(client) + self._test_get_search_facets_result(client) + self._test_autocomplete(client) + self._test_suggest(client) + + def _test_get_search_simple(self, client): results = list(client.search(search_text="hotel")) assert len(results) == 7 results = list(client.search(search_text="motel")) assert len(results) == 2 - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_search_simple_with_top(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) + def _test_get_search_simple_with_top(self, client): results = list(client.search(search_text="hotel", top=3)) assert len(results) == 3 results = list(client.search(search_text="motel", top=3)) assert len(results) == 2 - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_search_filter(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - + def _test_get_search_filter(self, client): select = ["hotelName", "category", "description"] results = list(client.search( search_text="WiFi", @@ -76,13 +63,7 @@ def test_get_search_filter(self, api_key, endpoint, index_name, **kwargs): assert all(set(x) == expected for x in results) assert all(x["category"] == "Budget" for x in results) - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_search_filter_array(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - + def _test_get_search_filter_array(self, client): select = ["hotelName", "category", "description"] results = list(client.search( search_text="WiFi", @@ -103,26 +84,14 @@ def test_get_search_filter_array(self, api_key, endpoint, index_name, **kwargs): assert all(set(x) == expected for x in results) assert all(x["category"] == "Budget" for x in results) - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_search_counts(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - + def _test_get_search_counts(self, client): results = client.search(search_text="hotel") assert results.get_count() is None results = client.search(search_text="hotel", include_total_count=True) assert results.get_count() == 7 - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_search_coverage(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - + def _test_get_search_coverage(self, client): results = client.search(search_text="hotel") assert results.get_coverage() is None @@ -131,24 +100,12 @@ def test_get_search_coverage(self, api_key, endpoint, index_name, **kwargs): assert isinstance(cov, float) assert cov >= 50.0 - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_search_facets_none(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - + def _test_get_search_facets_none(self, client): select = ("hotelName", "category", "description") results = client.search(search_text="WiFi", select=",".join(select)) assert results.get_facets() is None - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_search_facets_result(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) - + def _test_get_search_facets_result(self, client): select = ("hotelName", "category", "description") results = client.search(search_text="WiFi", facets=["category"], @@ -161,21 +118,11 @@ def test_get_search_facets_result(self, api_key, endpoint, index_name, **kwargs) ] } - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_autocomplete(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) + def _test_autocomplete(self, client): results = client.autocomplete(search_text="mot", suggester_name="sg") assert results == [{"text": "motel", "query_plus_text": "motel"}] - @ResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_suggest(self, api_key, endpoint, index_name, **kwargs): - client = SearchClient( - endpoint, index_name, AzureKeyCredential(api_key) - ) + def _test_suggest(self, client): results = client.suggest(search_text="mot", suggester_name="sg") assert results == [ {"hotelId": "2", "text": "Cheapest hotel in town. Infact, a motel."}, diff --git a/sdk/search/azure-search-documents/tests/test_search_index_client_data_source_live.py b/sdk/search/azure-search-documents/tests/test_search_index_client_data_source_live.py index ba7c4d610f7d..3d0be989aa7c 100644 --- a/sdk/search/azure-search-documents/tests/test_search_index_client_data_source_live.py +++ b/sdk/search/azure-search-documents/tests/test_search_index_client_data_source_live.py @@ -3,105 +3,93 @@ # Licensed under the MIT License. See License.txt in the project root for # license information. # -------------------------------------------------------------------------- -import json -from os.path import dirname, join, realpath import pytest -from devtools_testutils import AzureMgmtTestCase - -from search_service_preparer import SearchServicePreparer, SearchResourceGroupPreparer -from azure_devtools.scenario_tests import ReplayableTest - from azure.core import MatchConditions -from azure.core.credentials import AzureKeyCredential from azure.core.exceptions import HttpResponseError +from devtools_testutils import AzureRecordedTestCase, recorded_by_proxy + +from search_service_preparer import SearchEnvVarPreparer, search_decorator from azure.search.documents.indexes.models import( SearchIndexerDataSourceConnection, SearchIndexerDataContainer, ) from azure.search.documents.indexes import SearchIndexerClient -CWD = dirname(realpath(__file__)) -SCHEMA = open(join(CWD, "hotel_schema.json")).read() -try: - BATCH = json.load(open(join(CWD, "hotel_small.json"))) -except UnicodeDecodeError: - BATCH = json.load(open(join(CWD, "hotel_small.json"), encoding='utf-8')) -TIME_TO_SLEEP = 5 - -class SearchDataSourcesClientTest(AzureMgmtTestCase): - FILTER_HEADERS = ReplayableTest.FILTER_HEADERS + ['api-key'] +class TestSearchClientDataSources(AzureRecordedTestCase): - def _create_data_source_connection(self, name="sample-datasource"): + def _create_data_source_connection(self, cs, name): container = SearchIndexerDataContainer(name='searchcontainer') data_source_connection = SearchIndexerDataSourceConnection( name=name, type="azureblob", - connection_string=self.settings.AZURE_STORAGE_CONNECTION_STRING, + connection_string=cs, container=container ) return data_source_connection - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_create_datasource(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - data_source_connection = self._create_data_source_connection() + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy + def test_data_source(self, endpoint, api_key, **kwargs): + storage_cs = kwargs.get("search_storage_connection_string") + client = SearchIndexerClient(endpoint, api_key) + self._test_create_datasource(client, storage_cs) + self._test_delete_datasource(client, storage_cs) + self._test_get_datasource(client, storage_cs) + self._test_list_datasources(client, storage_cs) + self._test_create_or_update_datasource(client, storage_cs) + self._test_create_or_update_datasource_if_unchanged(client, storage_cs) + self._test_delete_datasource_if_unchanged(client, storage_cs) + self._test_delete_datasource_string_if_unchanged(client, storage_cs) + + def _test_create_datasource(self, client, storage_cs): + ds_name = "create" + data_source_connection = self._create_data_source_connection(storage_cs, ds_name) result = client.create_data_source_connection(data_source_connection) - assert result.name == "sample-datasource" + assert result.name == ds_name assert result.type == "azureblob" - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_delete_datasource(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - data_source_connection = self._create_data_source_connection() - result = client.create_data_source_connection(data_source_connection) - assert len(client.get_data_source_connections()) == 1 - client.delete_data_source_connection("sample-datasource") - assert len(client.get_data_source_connections()) == 0 - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_datasource(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - data_source_connection = self._create_data_source_connection() - created = client.create_data_source_connection(data_source_connection) - result = client.get_data_source_connection("sample-datasource") - assert result.name == "sample-datasource" - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_list_datasource(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - data_source_connection1 = self._create_data_source_connection() - data_source_connection2 = self._create_data_source_connection(name="another-sample") - created1 = client.create_data_source_connection(data_source_connection1) - created2 = client.create_data_source_connection(data_source_connection2) + def _test_delete_datasource(self, client, storage_cs): + ds_name = "delete" + data_source_connection = self._create_data_source_connection(storage_cs, ds_name) + client.create_data_source_connection(data_source_connection) + expected_count = len(client.get_data_source_connections()) - 1 + client.delete_data_source_connection(ds_name) + assert len(client.get_data_source_connections()) == expected_count + + def _test_get_datasource(self, client, storage_cs): + ds_name = "get" + data_source_connection = self._create_data_source_connection(storage_cs, ds_name) + client.create_data_source_connection(data_source_connection) + result = client.get_data_source_connection(ds_name) + assert result.name == ds_name + + def _test_list_datasources(self, client, storage_cs): + data_source_connection1 = self._create_data_source_connection(storage_cs, "list") + data_source_connection2 = self._create_data_source_connection(storage_cs, "list2") + client.create_data_source_connection(data_source_connection1) + client.create_data_source_connection(data_source_connection2) result = client.get_data_source_connections() assert isinstance(result, list) - assert set(x.name for x in result) == {"sample-datasource", "another-sample"} + assert set(x.name for x in result).intersection(set(["list", "list2"])) == set(["list", "list2"]) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_create_or_update_datasource(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - data_source_connection = self._create_data_source_connection() - created = client.create_data_source_connection(data_source_connection) - assert len(client.get_data_source_connections()) == 1 + def _test_create_or_update_datasource(self, client, storage_cs): + ds_name = "cou" + data_source_connection = self._create_data_source_connection(storage_cs, ds_name) + client.create_data_source_connection(data_source_connection) + expected_count = len(client.get_data_source_connections()) data_source_connection.description = "updated" client.create_or_update_data_source_connection(data_source_connection) - assert len(client.get_data_source_connections()) == 1 - result = client.get_data_source_connection("sample-datasource") - assert result.name == "sample-datasource" + assert len(client.get_data_source_connections()) == expected_count + result = client.get_data_source_connection(ds_name) + assert result.name == ds_name assert result.description == "updated" - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_create_or_update_datasource_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - data_source_connection = self._create_data_source_connection() + def _test_create_or_update_datasource_if_unchanged(self, client, storage_cs): + ds_name = "couunch" + data_source_connection = self._create_data_source_connection(storage_cs, ds_name) created = client.create_data_source_connection(data_source_connection) etag = created.e_tag @@ -115,11 +103,9 @@ def test_create_or_update_datasource_if_unchanged(self, api_key, endpoint, index with pytest.raises(HttpResponseError): client.create_or_update_data_source_connection(data_source_connection, match_condition=MatchConditions.IfNotModified) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_delete_datasource_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - data_source_connection = self._create_data_source_connection() + def _test_delete_datasource_if_unchanged(self, client, storage_cs): + ds_name = "delunch" + data_source_connection = self._create_data_source_connection(storage_cs, ds_name) created = client.create_data_source_connection(data_source_connection) etag = created.e_tag @@ -131,13 +117,10 @@ def test_delete_datasource_if_unchanged(self, api_key, endpoint, index_name, **k data_source_connection.e_tag = etag # reset to the original data source connection with pytest.raises(HttpResponseError): client.delete_data_source_connection(data_source_connection, match_condition=MatchConditions.IfNotModified) - assert len(client.get_data_source_connections()) == 1 - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_delete_datasource_string_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - data_source_connection = self._create_data_source_connection() + def _test_delete_datasource_string_if_unchanged(self, client, storage_cs): + ds_name = "delstrunch" + data_source_connection = self._create_data_source_connection(storage_cs, ds_name) created = client.create_data_source_connection(data_source_connection) etag = created.e_tag diff --git a/sdk/search/azure-search-documents/tests/test_search_index_client_live.py b/sdk/search/azure-search-documents/tests/test_search_index_client_live.py index c9cf9b2235cf..3cc0ca73e6c0 100644 --- a/sdk/search/azure-search-documents/tests/test_search_index_client_live.py +++ b/sdk/search/azure-search-documents/tests/test_search_index_client_live.py @@ -3,17 +3,9 @@ # Licensed under the MIT License. See License.txt in the project root for # license information. # -------------------------------------------------------------------------- -import json -from os.path import dirname, join, realpath import pytest - -from devtools_testutils import AzureMgmtTestCase -from azure_devtools.scenario_tests import ReplayableTest -from search_service_preparer import SearchServicePreparer, SearchResourceGroupPreparer - from azure.core import MatchConditions -from azure.core.credentials import AzureKeyCredential from azure.core.exceptions import HttpResponseError from azure.search.documents.indexes.models import( AnalyzeTextOptions, @@ -24,115 +16,57 @@ SearchFieldDataType ) from azure.search.documents.indexes import SearchIndexClient - -CWD = dirname(realpath(__file__)) -SCHEMA = open(join(CWD, "hotel_schema.json")).read() -try: - BATCH = json.load(open(join(CWD, "hotel_small.json"))) -except UnicodeDecodeError: - BATCH = json.load(open(join(CWD, "hotel_small.json"), encoding='utf-8')) -TIME_TO_SLEEP = 5 - -class SearchIndexClientTest(AzureMgmtTestCase): - FILTER_HEADERS = ReplayableTest.FILTER_HEADERS + ['api-key'] - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer() - def test_get_service_statistics(self, api_key, endpoint, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) +from devtools_testutils import AzureRecordedTestCase, recorded_by_proxy +from search_service_preparer import SearchEnvVarPreparer, search_decorator + + +class TestSearchIndexClient(AzureRecordedTestCase): + + @SearchEnvVarPreparer() + @search_decorator(schema=None, index_batch=None) + @recorded_by_proxy + def test_search_index_client(self, api_key, endpoint, index_name): + client = SearchIndexClient(endpoint, api_key) + index_name = "hotels" + self._test_get_service_statistics(client) + self._test_list_indexes_empty(client) + self._test_create_index(client, index_name) + self._test_list_indexes(client, index_name) + self._test_get_index(client, index_name) + self._test_get_index_statistics(client, index_name) + self._test_delete_indexes_if_unchanged(client) + self._test_create_or_update_index(client) + self._test_create_or_update_indexes_if_unchanged(client) + self._test_analyze_text(client, index_name) + self._test_delete_indexes(client) + + def _test_get_service_statistics(self, client): result = client.get_service_statistics() assert isinstance(result, dict) assert set(result.keys()) == {"counters", "limits"} - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer() - def test_list_indexes_empty(self, api_key, endpoint, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + def _test_list_indexes_empty(self, client): result = client.list_indexes() with pytest.raises(StopIteration): next(result) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_list_indexes(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + def _test_list_indexes(self, client, index_name): result = client.list_indexes() - first = next(result) assert first.name == index_name with pytest.raises(StopIteration): next(result) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_index(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + def _test_get_index(self, client, index_name): result = client.get_index(index_name) assert result.name == index_name - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_index_statistics(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + def _test_get_index_statistics(self, client, index_name): result = client.get_index_statistics(index_name) assert set(result.keys()) == {'document_count', 'storage_size'} - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_delete_indexes(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) - client.delete_index(index_name) - import time - if self.is_live: - time.sleep(TIME_TO_SLEEP) - result = client.list_indexes() - with pytest.raises(StopIteration): - next(result) - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_delete_indexes_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) - - # First create an index - name = "hotels" - fields = [ - { - "name": "hotelId", - "type": "Edm.String", - "key": True, - "searchable": False - }, - { - "name": "baseRate", - "type": "Edm.Double" - }] - scoring_profile = ScoringProfile( - name="MyProfile" - ) - scoring_profiles = [] - scoring_profiles.append(scoring_profile) - cors_options = CorsOptions(allowed_origins=["*"], max_age_in_seconds=60) - index = SearchIndex( - name=name, - fields=fields, - scoring_profiles=scoring_profiles, - cors_options=cors_options) - result = client.create_index(index) - etag = result.e_tag - # get e tag and update - index.scoring_profiles = [] - client.create_or_update_index(index) - - index.e_tag = etag - with pytest.raises(HttpResponseError): - client.delete_index(index, match_condition=MatchConditions.IfNotModified) - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_create_index(self, api_key, endpoint, index_name, **kwargs): - name = "hotels" + def _test_create_index(self, client, index_name): fields = [ SimpleField(name="hotelId", type=SearchFieldDataType.String, key=True), SimpleField(name="baseRate", type=SearchFieldDataType.Double) @@ -144,21 +78,18 @@ def test_create_index(self, api_key, endpoint, index_name, **kwargs): scoring_profiles.append(scoring_profile) cors_options = CorsOptions(allowed_origins=["*"], max_age_in_seconds=60) index = SearchIndex( - name=name, + name=index_name, fields=fields, scoring_profiles=scoring_profiles, cors_options=cors_options) - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) result = client.create_index(index) - assert result.name == "hotels" + assert result.name == index_name assert result.scoring_profiles[0].name == scoring_profile.name assert result.cors_options.allowed_origins == cors_options.allowed_origins assert result.cors_options.max_age_in_seconds == cors_options.max_age_in_seconds - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_create_or_update_index(self, api_key, endpoint, index_name, **kwargs): - name = "hotels" + def _test_create_or_update_index(self, client): + name = "hotels-cou" fields = [ SimpleField(name="hotelId", type=SearchFieldDataType.String, key=True), SimpleField(name="baseRate", type=SearchFieldDataType.Double) @@ -170,7 +101,6 @@ def test_create_or_update_index(self, api_key, endpoint, index_name, **kwargs): fields=fields, scoring_profiles=scoring_profiles, cors_options=cors_options) - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) result = client.create_or_update_index(index=index) assert len(result.scoring_profiles) == 0 assert result.cors_options.allowed_origins == cors_options.allowed_origins @@ -190,13 +120,9 @@ def test_create_or_update_index(self, api_key, endpoint, index_name, **kwargs): assert result.cors_options.allowed_origins == cors_options.allowed_origins assert result.cors_options.max_age_in_seconds == cors_options.max_age_in_seconds - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_create_or_update_indexes_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) - + def _test_create_or_update_indexes_if_unchanged(self, client): # First create an index - name = "hotels" + name = "hotels-coa-unchanged" fields = [ { "name": "hotelId", @@ -229,10 +155,46 @@ def test_create_or_update_indexes_if_unchanged(self, api_key, endpoint, index_na with pytest.raises(HttpResponseError): client.create_or_update_index(index, match_condition=MatchConditions.IfNotModified) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_analyze_text(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + def _test_analyze_text(self, client, index_name): analyze_request = AnalyzeTextOptions(text="One's ", analyzer_name="standard.lucene") result = client.analyze_text(index_name, analyze_request) assert len(result.tokens) == 2 + + def _test_delete_indexes_if_unchanged(self, client): + # First create an index + name = "hotels-del-unchanged" + fields = [ + { + "name": "hotelId", + "type": "Edm.String", + "key": True, + "searchable": False + }, + { + "name": "baseRate", + "type": "Edm.Double" + }] + scoring_profile = ScoringProfile( + name="MyProfile" + ) + scoring_profiles = [] + scoring_profiles.append(scoring_profile) + cors_options = CorsOptions(allowed_origins=["*"], max_age_in_seconds=60) + index = SearchIndex( + name=name, + fields=fields, + scoring_profiles=scoring_profiles, + cors_options=cors_options) + result = client.create_index(index) + etag = result.e_tag + # get e tag and update + index.scoring_profiles = [] + client.create_or_update_index(index) + + index.e_tag = etag + with pytest.raises(HttpResponseError): + client.delete_index(index, match_condition=MatchConditions.IfNotModified) + + def _test_delete_indexes(self, client): + for index in client.list_indexes(): + client.delete_index(index) diff --git a/sdk/search/azure-search-documents/tests/test_search_index_client_skillset_live.py b/sdk/search/azure-search-documents/tests/test_search_index_client_skillset_live.py index a2eda6d5f787..708f47ad506b 100644 --- a/sdk/search/azure-search-documents/tests/test_search_index_client_skillset_live.py +++ b/sdk/search/azure-search-documents/tests/test_search_index_client_skillset_live.py @@ -3,18 +3,13 @@ # Licensed under the MIT License. See License.txt in the project root for # license information. # -------------------------------------------------------------------------- -import json -from os.path import dirname, join, realpath import pytest - -from devtools_testutils import AzureMgmtTestCase -from azure_devtools.scenario_tests import ReplayableTest -from search_service_preparer import SearchServicePreparer, SearchResourceGroupPreparer - from azure.core import MatchConditions -from azure.core.credentials import AzureKeyCredential from azure.core.exceptions import HttpResponseError +from azure.core.credentials import AzureKeyCredential +from devtools_testutils import AzureRecordedTestCase, recorded_by_proxy +from search_service_preparer import SearchEnvVarPreparer, search_decorator from azure.search.documents.indexes.models import( EntityLinkingSkill, EntityRecognitionSkill, @@ -27,23 +22,57 @@ ) from azure.search.documents.indexes import SearchIndexerClient -CWD = dirname(realpath(__file__)) -SCHEMA = open(join(CWD, "hotel_schema.json")).read() -try: - BATCH = json.load(open(join(CWD, "hotel_small.json"))) -except UnicodeDecodeError: - BATCH = json.load(open(join(CWD, "hotel_small.json"), encoding='utf-8')) -TIME_TO_SLEEP = 5 -class SearchSkillsetClientTest(AzureMgmtTestCase): - FILTER_HEADERS = ReplayableTest.FILTER_HEADERS + ['api-key'] +class TestSearchSkillset(AzureRecordedTestCase): + + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy + def test_skillset_crud(self, api_key, endpoint): + client = SearchIndexerClient(endpoint, api_key) + self._test_create_skillset_validation() + self._test_create_skillset(client) + self._test_get_skillset(client) + self._test_get_skillsets(client) + # TODO: Disabled due to service regression. See #22769 + #self._test_create_or_update_skillset(client) + self._test_create_or_update_skillset_if_unchanged(client) + # TODO: Disabled due to service regression. See #22769 + #self._test_create_or_update_skillset_inplace(client) + # TODO: Disabled due to service regression. See #22769 + #self._test_delete_skillset_if_unchanged(client) + self._test_delete_skillset(client) + + def _test_create_skillset_validation(self): + name = "test-ss-validation" + with pytest.raises(ValueError) as err: + client = SearchIndexerClient("fake_endpoint", AzureKeyCredential("fake_key")) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_create_skillset(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - name = "test-ss" + s1 = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], + outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizationsS1")], + description="Skill Version 1", + model_version="1", + include_typeless_entities=True) + s2 = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], + outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizationsS2")], + skill_version=EntityRecognitionSkillVersion.LATEST, + description="Skill Version 3", + model_version="3", + include_typeless_entities=True) + s3 = SentimentSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], + outputs=[OutputFieldMappingEntry(name="score", target_name="scoreS3")], + skill_version=SentimentSkillVersion.V1, + description="Sentiment V1", + include_opinion_mining=True) + skillset = SearchIndexerSkillset(name=name, skills=list([s1, s2, s3]), description="desc") + client.create_skillset(skillset) + assert 'include_typeless_entities' in str(err.value) + assert 'model_version' in str(err.value) + assert 'include_opinion_mining' in str(err.value) + + def _test_create_skillset(self, client): + name = "test-ss-create" s1 = EntityRecognitionSkill(name="skill1", inputs=[InputFieldMappingEntry(name="text", source="/document/content")], outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizationsS1")], @@ -82,7 +111,7 @@ def test_create_skillset(self, api_key, endpoint, index_name, **kwargs): result = client.create_skillset(skillset) assert isinstance(result, SearchIndexerSkillset) - assert result.name == "test-ss" + assert result.name == name assert result.description == "desc" assert result.e_tag assert len(result.skills) == 5 @@ -98,154 +127,102 @@ def test_create_skillset(self, api_key, endpoint, index_name, **kwargs): assert result.skills[4].minimum_precision == 0.5 assert len(client.get_skillsets()) == 1 - client.reset_skills(result, [x.name for x in result.skills]) - - def test_create_skillset_validation(self, **kwargs): - with pytest.raises(ValueError) as err: - client = SearchIndexerClient("fake_endpoint", AzureKeyCredential("fake_key")) - name = "test-ss" - - s1 = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], - outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizationsS1")], - description="Skill Version 1", - model_version="1", - include_typeless_entities=True) - - s2 = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], - outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizationsS2")], - skill_version=EntityRecognitionSkillVersion.LATEST, - description="Skill Version 3", - model_version="3", - include_typeless_entities=True) - s3 = SentimentSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], - outputs=[OutputFieldMappingEntry(name="score", target_name="scoreS3")], - skill_version=SentimentSkillVersion.V1, - description="Sentiment V1", - include_opinion_mining=True) - skillset = SearchIndexerSkillset(name=name, skills=list([s1, s2, s3]), description="desc") - client.create_skillset(skillset) - assert 'include_typeless_entities' in str(err.value) - assert 'model_version' in str(err.value) - assert 'include_opinion_mining' in str(err.value) - - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_delete_skillset(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - s = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], - outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizations")]) - - skillset = SearchIndexerSkillset(name='test-ss', skills=list([s]), description="desc") - - result = client.create_skillset(skillset) - assert len(client.get_skillsets()) == 1 - - client.delete_skillset("test-ss") - assert len(client.get_skillsets()) == 0 - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_delete_skillset_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) + def _test_get_skillset(self, client): + name = "test-ss-get" s = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizations")]) - - skillset = SearchIndexerSkillset(name='test-ss', skills=list([s]), description="desc") - - result = client.create_skillset(skillset) - etag = result.e_tag - - skillset = SearchIndexerSkillset(name='test-ss', skills=list([s]), description="updated") - updated = client.create_or_update_skillset(skillset) - updated.e_tag = etag - - with pytest.raises(HttpResponseError): - client.delete_skillset(updated, match_condition=MatchConditions.IfNotModified) - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_skillset(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - s = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], - outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizations")]) - - skillset = SearchIndexerSkillset(name='test-ss', skills=list([s]), description="desc") + skillset = SearchIndexerSkillset(name=name, skills=list([s]), description="desc") client.create_skillset(skillset) - assert len(client.get_skillsets()) == 1 - - result = client.get_skillset("test-ss") + result = client.get_skillset(name) assert isinstance(result, SearchIndexerSkillset) - assert result.name == "test-ss" + assert result.name == name assert result.description == "desc" assert result.e_tag assert len(result.skills) == 1 assert isinstance(result.skills[0], EntityRecognitionSkill) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_skillsets(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) + def _test_get_skillsets(self, client): + name1 = "test-ss-list-1" + name2 = "test-ss-list-2" s = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizations")]) - skillset1 = SearchIndexerSkillset(name='test-ss-1', skills=list([s]), description="desc1") + skillset1 = SearchIndexerSkillset(name=name1, skills=list([s]), description="desc1") client.create_skillset(skillset1) - skillset2 = SearchIndexerSkillset(name='test-ss-2', skills=list([s]), description="desc2") + skillset2 = SearchIndexerSkillset(name=name2, skills=list([s]), description="desc2") client.create_skillset(skillset2) result = client.get_skillsets() assert isinstance(result, list) assert all(isinstance(x, SearchIndexerSkillset) for x in result) - assert set(x.name for x in result) == {"test-ss-1", "test-ss-2"} + assert set(x.name for x in result).intersection([name1, name2]) == set([name1, name2]) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_create_or_update_skillset(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) + def _test_create_or_update_skillset(self, client): + name = "test-ss-create-or-update" s = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizations")]) - skillset1 = SearchIndexerSkillset(name='test-ss', skills=list([s]), description="desc1") + skillset1 = SearchIndexerSkillset(name=name, skills=list([s]), description="desc1") client.create_or_update_skillset(skillset1) - skillset2 = SearchIndexerSkillset(name='test-ss', skills=list([s]), description="desc2") + expected_count = len(client.get_skillsets()) + skillset2 = SearchIndexerSkillset(name=name, skills=list([s]), description="desc2") client.create_or_update_skillset(skillset2) - assert len(client.get_skillsets()) == 1 + assert len(client.get_skillsets()) == expected_count - result = client.get_skillset("test-ss") + result = client.get_skillset(name) assert isinstance(result, SearchIndexerSkillset) - assert result.name == "test-ss" + assert result.name == name assert result.description == "desc2" - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_create_or_update_skillset_inplace(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) + def _test_create_or_update_skillset_inplace(self, client): + name = "test-ss-create-or-update-inplace" s = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizations")]) - skillset1 = SearchIndexerSkillset(name='test-ss', skills=list([s]), description="desc1") + skillset1 = SearchIndexerSkillset(name=name, skills=list([s]), description="desc1") ss = client.create_or_update_skillset(skillset1) - skillset2 = SearchIndexerSkillset(name='test-ss', skills=[s], description="desc2", skillset=ss) + expected_count = len(client.get_skillsets()) + skillset2 = SearchIndexerSkillset(name=name, skills=[s], description="desc2", skillset=ss) client.create_or_update_skillset(skillset2) - assert len(client.get_skillsets()) == 1 + assert len(client.get_skillsets()) == expected_count - result = client.get_skillset("test-ss") + result = client.get_skillset(name) assert isinstance(result, SearchIndexerSkillset) - assert result.name == "test-ss" + assert result.name == name assert result.description == "desc2" - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_create_or_update_skillset_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) + def _test_create_or_update_skillset_if_unchanged(self, client): + name = "test-ss-create-or-update-unchanged" s = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizations")]) - skillset1 = SearchIndexerSkillset(name='test-ss', skills=list([s]), description="desc1") + skillset1 = SearchIndexerSkillset(name=name, skills=list([s]), description="desc1") ss = client.create_or_update_skillset(skillset1) etag = ss.e_tag - skillset2 = SearchIndexerSkillset(name='test-ss', skills=[s], description="desc2", skillset=ss) - client.create_or_update_skillset(skillset2) - assert len(client.get_skillsets()) == 1 + + updated = SearchIndexerSkillset(name=name, skills=[s], description="desc2", skillset=ss) + updated.e_tag = etag + with pytest.raises(HttpResponseError): + client.create_or_update_skillset(updated, match_condition=MatchConditions.IfNotModified) + + def _test_delete_skillset_if_unchanged(self, client): + name = "test-ss-deleted-unchanged" + s = EntityRecognitionSkill(inputs=[InputFieldMappingEntry(name="text", source="/document/content")], + outputs=[OutputFieldMappingEntry(name="organizations", target_name="organizations")]) + + skillset = SearchIndexerSkillset(name=name, skills=list([s]), description="desc") + + result = client.create_skillset(skillset) + etag = result.e_tag + + skillset = SearchIndexerSkillset(name=name, skills=list([s]), description="updated") + updated = client.create_or_update_skillset(skillset) + updated.e_tag = etag + + with pytest.raises(HttpResponseError): + client.delete_skillset(updated, match_condition=MatchConditions.IfNotModified) + + def _test_delete_skillset(self, client): + for skillset in client.get_skillset_names(): + client.delete_skillset(skillset) diff --git a/sdk/search/azure-search-documents/tests/test_search_index_client_synonym_map_live.py b/sdk/search/azure-search-documents/tests/test_search_index_client_synonym_map_live.py index e2fe730c044d..048387eec8aa 100644 --- a/sdk/search/azure-search-documents/tests/test_search_index_client_synonym_map_live.py +++ b/sdk/search/azure-search-documents/tests/test_search_index_client_synonym_map_live.py @@ -3,75 +3,69 @@ # Licensed under the MIT License. See License.txt in the project root for # license information. # -------------------------------------------------------------------------- -import json -from os.path import dirname, join, realpath import pytest -from devtools_testutils import AzureMgmtTestCase -from azure_devtools.scenario_tests import ReplayableTest -from search_service_preparer import SearchServicePreparer, SearchResourceGroupPreparer - from azure.core import MatchConditions -from azure.core.credentials import AzureKeyCredential from azure.core.exceptions import HttpResponseError -from azure.search.documents.indexes.models import( - SynonymMap, -) from azure.search.documents.indexes import SearchIndexClient +from azure.search.documents.indexes.models import SynonymMap +from devtools_testutils import AzureRecordedTestCase, recorded_by_proxy + +from search_service_preparer import SearchEnvVarPreparer, search_decorator + -CWD = dirname(realpath(__file__)) -SCHEMA = open(join(CWD, "hotel_schema.json")).read() -try: - BATCH = json.load(open(join(CWD, "hotel_small.json"))) -except UnicodeDecodeError: - BATCH = json.load(open(join(CWD, "hotel_small.json"), encoding='utf-8')) -TIME_TO_SLEEP = 5 +class TestSearchClientSynonymMaps(AzureRecordedTestCase): -class SearchSynonymMapsClientTest(AzureMgmtTestCase): - FILTER_HEADERS = ReplayableTest.FILTER_HEADERS + ['api-key'] + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy + def test_synonym_map(self, endpoint, api_key): + client = SearchIndexClient(endpoint, api_key) + self._test_create_synonym_map(client) + self._test_delete_synonym_map(client) + self._test_delete_synonym_map_if_unchanged(client) + self._test_get_synonym_map(client) + self._test_get_synonym_maps(client) + self._test_create_or_update_synonym_map(client) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_create_synonym_map(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + def _test_create_synonym_map(self, client): + expected = len(client.get_synonym_maps()) + 1 + name = "synmap-create" synonyms = [ "USA, United States, United States of America", "Washington, Wash. => WA", ] - synonym_map = SynonymMap(name="test-syn-map", synonyms=synonyms) + synonym_map = SynonymMap(name=name, synonyms=synonyms) result = client.create_synonym_map(synonym_map) assert isinstance(result, SynonymMap) - assert result.name == "test-syn-map" + assert result.name == name assert result.synonyms == [ "USA, United States, United States of America", "Washington, Wash. => WA", ] - assert len(client.get_synonym_maps()) == 1 + assert len(client.get_synonym_maps()) == expected + client.delete_synonym_map(name) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_delete_synonym_map(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + def _test_delete_synonym_map(self, client): + name = "synmap-del" synonyms = [ "USA, United States, United States of America", "Washington, Wash. => WA", ] - synonym_map = SynonymMap(name="test-syn-map", synonyms=synonyms) + synonym_map = SynonymMap(name=name, synonyms=synonyms) result = client.create_synonym_map(synonym_map) - assert len(client.get_synonym_maps()) == 1 - client.delete_synonym_map("test-syn-map") - assert len(client.get_synonym_maps()) == 0 + expected = len(client.get_synonym_maps()) - 1 + client.delete_synonym_map(name) + assert len(client.get_synonym_maps()) == expected - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_delete_synonym_map_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + def _test_delete_synonym_map_if_unchanged(self, client): + name = "synmap-delunch" synonyms = [ "USA, United States, United States of America", "Washington, Wash. => WA", ] - synonym_map = SynonymMap(name="test-syn-map", synonyms=synonyms) + synonym_map = SynonymMap(name=name, synonyms=synonyms) result = client.create_synonym_map(synonym_map) etag = result.e_tag @@ -83,85 +77,68 @@ def test_delete_synonym_map_if_unchanged(self, api_key, endpoint, index_name, ** result.e_tag = etag with pytest.raises(HttpResponseError): client.delete_synonym_map(result, match_condition=MatchConditions.IfNotModified) - assert len(client.get_synonym_maps()) == 1 + client.delete_synonym_map(name) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_synonym_map(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + def _test_get_synonym_map(self, client): + expected = len(client.get_synonym_maps()) + 1 + name = "synmap-get" synonyms = [ "USA, United States, United States of America", "Washington, Wash. => WA", ] - synonym_map = SynonymMap(name="test-syn-map", synonyms=synonyms) + synonym_map = SynonymMap(name=name, synonyms=synonyms) client.create_synonym_map(synonym_map) - assert len(client.get_synonym_maps()) == 1 - result = client.get_synonym_map("test-syn-map") + assert len(client.get_synonym_maps()) == expected + result = client.get_synonym_map(name) assert isinstance(result, SynonymMap) - assert result.name == "test-syn-map" + assert result.name == name assert result.synonyms == [ "USA, United States, United States of America", "Washington, Wash. => WA", ] + client.delete_synonym_map(name) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_synonym_maps(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + def _test_get_synonym_maps(self, client): + name1 = "synmap-list1" + name2 = "synmap-list2" synonyms = [ "USA, United States, United States of America", + "Washington, Wash. => WA", ] - synonym_map_1 = SynonymMap(name="test-syn-map-1", synonyms=synonyms) + synonym_map_1 = SynonymMap(name=name1, synonyms=synonyms) client.create_synonym_map(synonym_map_1) synonyms = [ "Washington, Wash. => WA", ] - synonym_map_2 = SynonymMap(name="test-syn-map-2", synonyms=synonyms) + synonym_map_2 = SynonymMap(name=name2, synonyms=synonyms) client.create_synonym_map(synonym_map_2) result = client.get_synonym_maps() assert isinstance(result, list) assert all(isinstance(x, SynonymMap) for x in result) - assert set(x.name for x in result) == {"test-syn-map-1", "test-syn-map-2"} - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_create_or_update_synonym_map(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) + expected = set([name1, name2]) + assert set(x.name for x in result).intersection(expected) == expected + client.delete_synonym_map(name1) + client.delete_synonym_map(name2) + + def _test_create_or_update_synonym_map(self, client): + expected = len(client.get_synonym_maps()) + 1 + name = "synmap-cou" synonyms = [ "USA, United States, United States of America", "Washington, Wash. => WA", ] - synonym_map = SynonymMap(name="test-syn-map", synonyms=synonyms) + synonym_map = SynonymMap(name=name, synonyms=synonyms) client.create_synonym_map(synonym_map) - assert len(client.get_synonym_maps()) == 1 - synonym_map.synonyms = ["Washington, Wash. => WA",] + assert len(client.get_synonym_maps()) == expected + synonym_map.synonyms = [ + "Washington, Wash. => WA", + ] client.create_or_update_synonym_map(synonym_map) - assert len(client.get_synonym_maps()) == 1 - result = client.get_synonym_map("test-syn-map") + assert len(client.get_synonym_maps()) == expected + result = client.get_synonym_map(name) assert isinstance(result, SynonymMap) - assert result.name == "test-syn-map" + assert result.name == name assert result.synonyms == [ "Washington, Wash. => WA", ] - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_create_or_update_synonym_map_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexClient(endpoint, AzureKeyCredential(api_key)) - synonyms = [ - "USA, United States, United States of America", - "Washington, Wash. => WA", - ] - synonym_map = SynonymMap(name="test-syn-map", synonyms=synonyms) - result = client.create_synonym_map(synonym_map) - etag = result.e_tag - - synonym_map.synonyms = [ - "Washington, Wash. => WA", - ] - - client.create_or_update_synonym_map(synonym_map) - - result.e_tag = etag - with pytest.raises(HttpResponseError): - client.create_or_update_synonym_map(result, match_condition=MatchConditions.IfNotModified) + client.delete_synonym_map(name) diff --git a/sdk/search/azure-search-documents/tests/test_search_indexer_client_live.py b/sdk/search/azure-search-documents/tests/test_search_indexer_client_live.py index bcb046b2c664..4bb398e53d1c 100644 --- a/sdk/search/azure-search-documents/tests/test_search_indexer_client_live.py +++ b/sdk/search/azure-search-documents/tests/test_search_indexer_client_live.py @@ -3,52 +3,49 @@ # Licensed under the MIT License. See License.txt in the project root for # license information. # -------------------------------------------------------------------------- -import json -from os.path import dirname, join, realpath -import time import pytest - -from devtools_testutils import AzureMgmtTestCase -from azure_devtools.scenario_tests import ReplayableTest -from search_service_preparer import SearchServicePreparer, SearchResourceGroupPreparer - from azure.core import MatchConditions -from azure.core.credentials import AzureKeyCredential from azure.core.exceptions import HttpResponseError -from azure.search.documents.indexes.models import( - SearchIndex, - SearchIndexerDataSourceConnection, - SearchIndexer, - SearchIndexerDataContainer, -) from azure.search.documents.indexes import SearchIndexClient, SearchIndexerClient - -CWD = dirname(realpath(__file__)) -SCHEMA = open(join(CWD, "hotel_schema.json")).read() -try: - BATCH = json.load(open(join(CWD, "hotel_small.json"))) -except UnicodeDecodeError: - BATCH = json.load(open(join(CWD, "hotel_small.json"), encoding="utf-8")) -TIME_TO_SLEEP = 5 - -class SearchIndexersClientTest(AzureMgmtTestCase): - FILTER_HEADERS = ReplayableTest.FILTER_HEADERS + ['api-key'] - - def _prepare_indexer(self, endpoint, api_key, name="sample-indexer", ds_name="sample-datasource", id_name="hotels"): - con_str = self.settings.AZURE_STORAGE_CONNECTION_STRING - self.scrubber.register_name_pair(con_str, 'connection_string') - container = SearchIndexerDataContainer(name='searchcontainer') +from azure.search.documents.indexes.models import ( + SearchIndex, SearchIndexer, SearchIndexerDataContainer, + SearchIndexerDataSourceConnection) +from devtools_testutils import AzureRecordedTestCase, recorded_by_proxy + +from search_service_preparer import SearchEnvVarPreparer, search_decorator + + +class TestSearchIndexerClientTest(AzureRecordedTestCase): + + @SearchEnvVarPreparer() + @search_decorator(schema="hotel_schema.json", index_batch="hotel_small.json") + @recorded_by_proxy + def test_search_indexers(self, endpoint, api_key, **kwargs): + storage_cs = kwargs.get("search_storage_connection_string") + container_name = kwargs.get("search_storage_container_name") + client = SearchIndexerClient(endpoint, api_key) + index_client = SearchIndexClient(endpoint, api_key) + self._test_create_indexer(client, index_client, storage_cs, container_name) + self._test_delete_indexer(client, index_client, storage_cs, container_name) + self._test_get_indexer(client, index_client, storage_cs, container_name) + self._test_list_indexer(client, index_client, storage_cs, container_name) + self._test_create_or_update_indexer(client, index_client, storage_cs, container_name) + self._test_reset_indexer(client, index_client, storage_cs, container_name) + self._test_run_indexer(client, index_client, storage_cs, container_name) + self._test_get_indexer_status(client, index_client, storage_cs, container_name) + self._test_create_or_update_indexer_if_unchanged(client, index_client, storage_cs, container_name) + self._test_delete_indexer_if_unchanged(client, index_client, storage_cs, container_name) + + def _prepare_indexer(self, client, index_client, storage_cs, name, container_name): data_source_connection = SearchIndexerDataSourceConnection( - name=ds_name, + name=f"{name}-ds", type="azureblob", - connection_string=con_str, - container=container + connection_string=storage_cs, + container=SearchIndexerDataContainer(name=container_name) ) - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) ds = client.create_data_source_connection(data_source_connection) - index_name = id_name fields = [ { "name": "hotelId", @@ -56,104 +53,83 @@ def _prepare_indexer(self, endpoint, api_key, name="sample-indexer", ds_name="sa "key": True, "searchable": False }] - index = SearchIndex(name=index_name, fields=fields) - ind = SearchIndexClient(endpoint, AzureKeyCredential(api_key)).create_index(index) + index = SearchIndex(name=f"{name}-hotels", fields=fields) + ind = index_client.create_index(index) return SearchIndexer(name=name, data_source_name=ds.name, target_index_name=ind.name) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_create_indexer(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer = self._prepare_indexer(endpoint, api_key) - result = client.create_indexer(indexer) - assert result.name == "sample-indexer" - assert result.target_index_name == "hotels" - assert result.data_source_name == "sample-datasource" - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_delete_indexer(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer = self._prepare_indexer(endpoint, api_key) - result = client.create_indexer(indexer) - assert len(client.get_indexers()) == 1 - client.delete_indexer("sample-indexer") - assert len(client.get_indexers()) == 0 - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_reset_indexer(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer = self._prepare_indexer(endpoint, api_key) + def _test_create_indexer(self, client, index_client, storage_cs, container_name): + name = "create" + indexer = self._prepare_indexer(client, index_client, storage_cs, name, container_name) result = client.create_indexer(indexer) - assert len(client.get_indexers()) == 1 - result = client.reset_indexer("sample-indexer") - assert client.get_indexer_status("sample-indexer").last_result.status.lower() in ('inprogress', 'reset') - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_run_indexer(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer = self._prepare_indexer(endpoint, api_key) - result = client.create_indexer(indexer) - assert len(client.get_indexers()) == 1 - start = time.time() - client.run_indexer("sample-indexer") - assert client.get_indexer_status("sample-indexer").status == 'running' - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_indexer(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer = self._prepare_indexer(endpoint, api_key) - created = client.create_indexer(indexer) - result = client.get_indexer("sample-indexer") - assert result.name == "sample-indexer" - - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_list_indexer(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer1 = self._prepare_indexer(endpoint, api_key) - indexer2 = self._prepare_indexer(endpoint, api_key, name="another-indexer", ds_name="another-datasource", id_name="another-index") - created1 = client.create_indexer(indexer1) - created2 = client.create_indexer(indexer2) + assert result.name == name + assert result.target_index_name == f"{name}-hotels" + assert result.data_source_name == f"{name}-ds" + + def _test_delete_indexer(self, client, index_client, storage_cs, container_name): + name = "delete" + indexer = self._prepare_indexer(client, index_client, storage_cs, name, container_name) + client.create_indexer(indexer) + expected = len(client.get_indexers()) - 1 + client.delete_indexer(name) + assert len(client.get_indexers()) == expected + + def _test_get_indexer(self, client, index_client, storage_cs, container_name): + name = "get" + indexer = self._prepare_indexer(client, index_client, storage_cs, name, container_name) + client.create_indexer(indexer) + result = client.get_indexer(name) + assert result.name == name + + def _test_list_indexer(self, client, index_client, storage_cs, container_name): + name1 = "list1" + name2 = "list2" + indexer1 = self._prepare_indexer(client, index_client, storage_cs, name1, container_name) + indexer2 = self._prepare_indexer(client, index_client, storage_cs, name2, container_name) + client.create_indexer(indexer1) + client.create_indexer(indexer2) result = client.get_indexers() assert isinstance(result, list) - assert set(x.name for x in result) == {"sample-indexer", "another-indexer"} + assert set(x.name for x in result).intersection([name1, name2]) == set([name1, name2]) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_create_or_update_indexer(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer = self._prepare_indexer(endpoint, api_key) - created = client.create_indexer(indexer) - assert len(client.get_indexers()) == 1 + def _test_create_or_update_indexer(self, client, index_client, storage_cs, container_name): + name = "cou" + indexer = self._prepare_indexer(client, index_client, storage_cs, name, container_name) + client.create_indexer(indexer) + expected = len(client.get_indexers()) indexer.description = "updated" client.create_or_update_indexer(indexer) - assert len(client.get_indexers()) == 1 - result = client.get_indexer("sample-indexer") - assert result.name == "sample-indexer" + assert len(client.get_indexers()) == expected + result = client.get_indexer(name) + assert result.name == name assert result.description == "updated" - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_get_indexer_status(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer = self._prepare_indexer(endpoint, api_key) - result = client.create_indexer(indexer) - status = client.get_indexer_status("sample-indexer") + def _test_reset_indexer(self, client, index_client, storage_cs, container_name): + name = "reset" + indexer = self._prepare_indexer(client, index_client, storage_cs, name, container_name) + client.create_indexer(indexer) + client.reset_indexer(name) + assert (client.get_indexer_status(name)).last_result.status.lower() in ('inprogress', 'reset') + + def _test_run_indexer(self, client, index_client, storage_cs, container_name): + name = "run" + indexer = self._prepare_indexer(client, index_client, storage_cs, name, container_name) + client.create_indexer(indexer) + client.run_indexer(name) + assert (client.get_indexer_status(name)).status == 'running' + + def _test_get_indexer_status(self, client, index_client, storage_cs, container_name): + name = "get-status" + indexer = self._prepare_indexer(client, index_client, storage_cs, name, container_name) + client.create_indexer(indexer) + status = client.get_indexer_status(name) assert status.status is not None - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_create_or_update_indexer_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer = self._prepare_indexer(endpoint, api_key) + def _test_create_or_update_indexer_if_unchanged(self, client, index_client, storage_cs, container_name): + name = "couunch" + indexer = self._prepare_indexer(client, index_client, storage_cs, name, container_name) created = client.create_indexer(indexer) etag = created.e_tag - indexer.description = "updated" client.create_or_update_indexer(indexer) @@ -161,11 +137,9 @@ def test_create_or_update_indexer_if_unchanged(self, api_key, endpoint, index_na with pytest.raises(HttpResponseError): client.create_or_update_indexer(indexer, match_condition=MatchConditions.IfNotModified) - @SearchResourceGroupPreparer(random_name_enabled=True) - @SearchServicePreparer(schema=SCHEMA, index_batch=BATCH) - def test_delete_indexer_if_unchanged(self, api_key, endpoint, index_name, **kwargs): - client = SearchIndexerClient(endpoint, AzureKeyCredential(api_key)) - indexer = self._prepare_indexer(endpoint, api_key) + def _test_delete_indexer_if_unchanged(self, client, index_client, storage_cs, container_name): + name = "delunch" + indexer = self._prepare_indexer(client, index_client, storage_cs, name, container_name) result = client.create_indexer(indexer) etag = result.e_tag diff --git a/sdk/search/test-resources.bicep b/sdk/search/test-resources.bicep new file mode 100644 index 000000000000..a2720494c1eb --- /dev/null +++ b/sdk/search/test-resources.bicep @@ -0,0 +1,48 @@ +param searchEndpointSuffix string = 'search.windows.net' +param storageEndpointSuffix string = 'core.windows.net' +param location string = '${resourceGroup().location}' +param searchSku string = 'standard' +param searchServiceName string = 'search-${uniqueString(resourceGroup().id)}' +param searchApiVersion string = '2021-04-01-Preview' +param storageAccountName string = 'storage${uniqueString(resourceGroup().id)}' +param storageContainerName string = 'storage-container-${resourceGroup().name}' +param storageApiVersion string = '2021-06-01' + +resource searchService 'Microsoft.Search/searchServices@2021-04-01-Preview' = { + name: searchServiceName + location: 'eastus2' // semantic search is available here + sku: { + name: searchSku + } + properties: { + semanticSearch: 'standard' + } +} + +resource storageService 'Microsoft.Storage/storageAccounts@2021-06-01' = { + name: storageAccountName + location: location + sku: { + /* cspell:disable-next-line */ + name: 'Standard_RAGRS' + } + kind: 'StorageV2' + properties: { + accessTier: 'Hot' + supportsHttpsTrafficOnly: true + } +} + +resource container 'Microsoft.Storage/storageAccounts/blobServices/containers@2021-06-01' = { + name: '${storageAccountName}/default/${storageContainerName}' + dependsOn: [ + storageService + ] +} + +output search_service_endpoint string = 'https://${searchServiceName}.${searchEndpointSuffix}' +output search_service_api_key string = searchService.listAdminKeys(searchApiVersion).primaryKey +output search_query_api_key string = searchService.listQueryKeys(searchApiVersion).value[0].key +output search_service_name string = searchServiceName +output search_storage_connection_string string = 'DefaultEndpointsProtocol=https;AccountName=${storageAccountName};AccountKey=${storageService.listKeys(storageApiVersion).keys[0].value};EndpointSuffix=${storageEndpointSuffix}' +output search_storage_container_name string = storageContainerName