diff --git a/.github/workflows/main.yaml b/.github/workflows/main.yaml index a84687f1e..3284dd25f 100644 --- a/.github/workflows/main.yaml +++ b/.github/workflows/main.yaml @@ -27,6 +27,7 @@ env: WEAVIATE_133: 1.33.10 WEAVIATE_134: 1.34.5 WEAVIATE_135: 1.35.0 + WEAVIATE_136: 1.36.0-dev-429d994.amd64 jobs: lint-and-format: @@ -305,8 +306,9 @@ jobs: $WEAVIATE_131, $WEAVIATE_132, $WEAVIATE_133, - $WEAVIATE_134 - $WEAVIATE_135 + $WEAVIATE_134, + $WEAVIATE_135, + $WEAVIATE_136 ] steps: - name: Checkout diff --git a/profiling/conftest.py b/profiling/conftest.py index aac8f3048..84658441d 100644 --- a/profiling/conftest.py +++ b/profiling/conftest.py @@ -61,6 +61,10 @@ def _factory( headers=headers, additional_config=AdditionalConfig(timeout=(60, 120)), # for image tests ) + # client_fixture = weaviate.connect_to_weaviate_cloud( + # cluster_url="flnyoj61teuw1mxfwf1fsa.c0.europe-west3.gcp.weaviate.cloud", + # auth_credentials=weaviate.auth.Auth.api_key("QnVtdnlnM2RYeUh3NVlFNF82V3pqVEtoYnloMlo0MHV2R2hYMU9BUFFsR3cvUUlkUG9CTFRiQXNjam1nPV92MjAw"), + # ) client_fixture.collections.delete(name_fixture) if integration_config is not None: client_fixture.integrations.configure(integration_config) diff --git a/profiling/test_sphere.py b/profiling/test_sphere.py index a2c225954..5d7a59fa4 100644 --- a/profiling/test_sphere.py +++ b/profiling/test_sphere.py @@ -28,7 +28,7 @@ def test_sphere(collection_factory: CollectionFactory) -> None: start = time.time() import_objects = 1000000 - with collection.batch.dynamic() as batch: + with collection.batch.experimental() as batch: with open(sphere_file) as jsonl_file: for i, jsonl in enumerate(jsonl_file): if i == import_objects or batch.number_errors > 10: @@ -46,7 +46,7 @@ def test_sphere(collection_factory: CollectionFactory) -> None: vector=json_parsed["vector"], ) if i % 1000 == 0: - print(f"Imported {len(collection)} objects") + print(f"Imported {len(collection)} objects after processing {i} lines") assert len(collection.batch.failed_objects) == 0 assert len(collection) == import_objects print(f"Imported {import_objects} objects in {time.time() - start}") diff --git a/weaviate/collections/batch/base.py b/weaviate/collections/batch/base.py index efc7dd163..9045e1846 100644 --- a/weaviate/collections/batch/base.py +++ b/weaviate/collections/batch/base.py @@ -13,7 +13,6 @@ from queue import Queue from typing import Any, Dict, Generator, Generic, List, Optional, Set, TypeVar, Union, cast -from httpx import ConnectError from pydantic import ValidationError from typing_extensions import TypeAlias @@ -29,8 +28,6 @@ ErrorObject, ErrorReference, Shard, - _BatchObject, - _BatchReference, ) from weaviate.collections.classes.config import ConsistencyLevel from weaviate.collections.classes.internal import ( @@ -42,7 +39,7 @@ from weaviate.connect import executor from weaviate.connect.v4 import ConnectionSync from weaviate.exceptions import ( - EmptyResponseException, + WeaviateBatchFailedToReestablishStreamError, WeaviateBatchStreamError, WeaviateBatchValidationError, WeaviateGRPCUnavailableError, @@ -95,7 +92,7 @@ def prepend(self, item: List[TBatchInput]) -> None: self._lock.release() -Ref = TypeVar("Ref", bound=Union[_BatchReference, batch_pb2.BatchReference]) +Ref = TypeVar("Ref", bound=BatchReference) class ReferencesBatchRequest(BatchRequest[Ref, BatchReferenceReturn]): @@ -111,8 +108,9 @@ def pop_items(self, pop_amount: int, uuid_lookup: Set[str]) -> List[Ref]: i = 0 self._lock.acquire() while len(ret) < pop_amount and len(self._items) > 0 and i < len(self._items): - if self._items[i].from_uuid not in uuid_lookup and ( - self._items[i].to_uuid is None or self._items[i].to_uuid not in uuid_lookup + if self._items[i].from_object_uuid not in uuid_lookup and ( + self._items[i].to_object_uuid is None + or self._items[i].to_object_uuid not in uuid_lookup ): ret.append(self._items.pop(i)) else: @@ -132,7 +130,7 @@ def head(self) -> Optional[Ref]: return item -Obj = TypeVar("Obj", bound=Union[_BatchObject, batch_pb2.BatchObject]) +Obj = TypeVar("Obj", bound=BatchObject) class ObjectsBatchRequest(Generic[Obj], BatchRequest[Obj, BatchObjectReturn]): @@ -210,11 +208,11 @@ def __init__( batch_mode: _BatchMode, executor: ThreadPoolExecutor, vectorizer_batching: bool, - objects: Optional[ObjectsBatchRequest] = None, - references: Optional[ReferencesBatchRequest] = None, + objects: Optional[ObjectsBatchRequest[BatchObject]] = None, + references: Optional[ReferencesBatchRequest[BatchReference]] = None, ) -> None: - self.__batch_objects = objects or ObjectsBatchRequest() - self.__batch_references = references or ReferencesBatchRequest() + self.__batch_objects = objects or ObjectsBatchRequest[BatchObject]() + self.__batch_references = references or ReferencesBatchRequest[BatchReference]() self.__connection = connection self.__consistency_level: Optional[ConsistencyLevel] = consistency_level @@ -530,8 +528,8 @@ def __dynamic_batching(self) -> None: def __send_batch( self, - objs: List[_BatchObject], - refs: List[_BatchReference], + objs: List[BatchObject], + refs: List[BatchReference], readd_rate_limit: bool, ) -> None: if (n_objs := len(objs)) > 0: @@ -540,7 +538,7 @@ def __send_batch( response_obj = executor.result( self.__batch_grpc.objects( connection=self.__connection, - objects=objs, + objects=[obj._to_internal() for obj in objs], timeout=DEFAULT_REQUEST_TIMEOUT, max_retries=MAX_RETRIES, ) @@ -554,8 +552,7 @@ def __send_batch( ) except Exception as e: errors_obj = { - idx: ErrorObject(message=repr(e), object_=BatchObject._from_internal(obj)) - for idx, obj in enumerate(objs) + idx: ErrorObject(message=repr(e), object_=obj) for idx, obj in enumerate(objs) } logger.error( { @@ -609,9 +606,7 @@ def __send_batch( ) readd_objects = [ - err.object_._to_internal() - for i, err in response_obj.errors.items() - if i in readded_objects + err.object_ for i, err in response_obj.errors.items() if i in readded_objects ] readded_uuids = {obj.uuid for obj in readd_objects} @@ -671,13 +666,14 @@ def __send_batch( start = time.time() try: response_ref = executor.result( - self.__batch_rest.references(connection=self.__connection, references=refs) + self.__batch_rest.references( + connection=self.__connection, + references=[ref._to_internal() for ref in refs], + ) ) except Exception as e: errors_ref = { - idx: ErrorReference( - message=repr(e), reference=BatchReference._from_internal(ref) - ) + idx: ErrorReference(message=repr(e), reference=ref) for idx, ref in enumerate(refs) } response_ref = BatchReferenceReturn( @@ -744,7 +740,7 @@ def _add_object( except ValidationError as e: raise WeaviateBatchValidationError(repr(e)) self.__uuid_lookup.add(str(batch_object.uuid)) - self.__batch_objects.add(batch_object._to_internal()) + self.__batch_objects.add(batch_object) # block if queue gets too long or weaviate is overloaded - reading files is faster them sending them so we do # not need a long queue @@ -790,7 +786,7 @@ def _add_reference( self.__refs_count += 1 except ValidationError as e: raise WeaviateBatchValidationError(repr(e)) - self.__batch_references.add(batch_reference._to_internal()) + self.__batch_references.add(batch_reference) # block if queue gets too long or weaviate is overloaded while self.__recommended_num_objects == 0: @@ -843,11 +839,11 @@ def __init__( batch_mode: _BatchMode, executor: ThreadPoolExecutor, vectorizer_batching: bool, - objects: Optional[ObjectsBatchRequest[batch_pb2.BatchObject]] = None, - references: Optional[ReferencesBatchRequest] = None, + objects: Optional[ObjectsBatchRequest[BatchObject]] = None, + references: Optional[ReferencesBatchRequest[BatchReference]] = None, ) -> None: - self.__batch_objects = objects or ObjectsBatchRequest[batch_pb2.BatchObject]() - self.__batch_references = references or ReferencesBatchRequest[batch_pb2.BatchReference]() + self.__batch_objects = objects or ObjectsBatchRequest[BatchObject]() + self.__batch_references = references or ReferencesBatchRequest[BatchReference]() self.__connection = connection self.__consistency_level: ConsistencyLevel = consistency_level or ConsistencyLevel.QUORUM @@ -856,6 +852,8 @@ def __init__( self.__batch_grpc = _BatchGRPC( connection._weaviate_version, self.__consistency_level, connection._grpc_max_msg_size ) + self.__cluster = _ClusterBatch(self.__connection) + self.__number_of_nodes = self.__cluster.get_number_of_nodes() # lookup table for objects that are currently being processed - is used to not send references from objects that have not been added yet self.__uuid_lookup: Set[str] = set() @@ -871,6 +869,7 @@ def __init__( self.__results_lock = threading.Lock() self.__bg_thread_exception: Optional[Exception] = None + self.__is_oom = threading.Event() self.__is_shutting_down = threading.Event() self.__is_shutdown = threading.Event() @@ -879,6 +878,10 @@ def __init__( self.__objs_cache: dict[str, BatchObject] = {} self.__refs_cache: dict[str, BatchReference] = {} + self.__acks_lock = threading.Lock() + self.__inflight_objs: set[str] = set() + self.__inflight_refs: set[str] = set() + # maxsize=1 so that __batch_send does not run faster than generator for __batch_recv # thereby using too much buffer in case of server-side shutdown self.__reqs: Queue[Optional[batch_pb2.BatchStreamRequest]] = Queue(maxsize=1) @@ -920,9 +923,9 @@ def _start(self) -> None: while not self.__all_threads_alive(): # wait for the stream to be started by __batch_stream time.sleep(0.01) - if time.time() - now > 10: - raise WeaviateBatchValidationError( - "Batch stream was not started within 10 seconds. Please check your connection." + if time.time() - now > 60: + raise WeaviateBatchStreamError( + "Batch stream was not started within 60 seconds. Please check your connection." ) def _shutdown(self) -> None: @@ -985,7 +988,12 @@ def __batch_send(self) -> None: for req in self.__generate_stream_requests(objs, refs): logged = False - while self.__is_shutting_down.is_set() or self.__is_shutdown.is_set(): + start = time.time() + while ( + self.__is_oom.is_set() + or self.__is_shutting_down.is_set() + or self.__is_shutdown.is_set() + ): # if we were shutdown by the node we were connected to, we need to wait for the stream to be restarted # so that the connection is refreshed to a new node where the objects can be accepted # otherwise, we wait until the stream has been started by __batch_stream to send the first batch @@ -995,6 +1003,10 @@ def __batch_send(self) -> None: # put sentinel into our queue to signal the end of the current stream self.__reqs.put(None) time.sleep(1) + if time.time() - start > 300: + raise WeaviateBatchFailedToReestablishStreamError( + "Batch stream was not re-established within 5 minutes. Terminating batch." + ) if logged: logger.warning("Stream re-established, resuming sending batches") self.__reqs.put(req) @@ -1005,10 +1017,13 @@ def __batch_send(self) -> None: return time.sleep(refresh_time) + def __beacon(self, ref: batch_pb2.BatchReference) -> str: + return f"weaviate://localhost/{ref.from_collection}{f'#{ref.tenant}' if ref.tenant != '' else ''}/{ref.from_uuid}#{ref.name}->/{ref.to_collection}/{ref.to_uuid}" + def __generate_stream_requests( self, - objs: List[batch_pb2.BatchObject], - refs: List[batch_pb2.BatchReference], + objects: List[BatchObject], + references: List[BatchReference], ) -> Generator[batch_pb2.BatchStreamRequest, None, None]: per_object_overhead = 4 # extra overhead bytes per object in the request @@ -1018,7 +1033,10 @@ def request_maker(): request = request_maker() total_size = request.ByteSize() - for obj in objs: + inflight_objs = set() + inflight_refs = set() + for object_ in objects: + obj = self.__batch_grpc.grpc_object(object_._to_internal()) obj_size = obj.ByteSize() + per_object_overhead if total_size + obj_size >= self.__batch_grpc.grpc_max_msg_size: @@ -1028,8 +1046,11 @@ def request_maker(): request.data.objects.values.append(obj) total_size += obj_size + if self.__connection._weaviate_version.is_at_least(1, 35, 0): + inflight_objs.add(obj.uuid) - for ref in refs: + for reference in references: + ref = self.__batch_grpc.grpc_reference(reference._to_internal()) ref_size = ref.ByteSize() + per_object_overhead if total_size + ref_size >= self.__batch_grpc.grpc_max_msg_size: @@ -1039,6 +1060,12 @@ def request_maker(): request.data.references.values.append(ref) total_size += ref_size + if self.__connection._weaviate_version.is_at_least(1, 35, 0): + inflight_refs.add(reference._to_beacon()) + + with self.__acks_lock: + self.__inflight_objs.update(inflight_objs) + self.__inflight_refs.update(inflight_refs) if len(request.data.objects.values) > 0 or len(request.data.references.values) > 0: yield request @@ -1069,6 +1096,9 @@ def __generate_stream_requests_for_grpc( if self.__is_shutting_down.is_set(): logger.warning("Server shutting down, closing the client-side of the stream") return + if self.__is_oom.is_set(): + logger.warning("Server out-of-memory, closing the client-side of the stream") + return logger.warning("Received sentinel, but not stopping, continuing...") def __batch_recv(self) -> None: @@ -1091,6 +1121,10 @@ def __batch_recv(self) -> None: logger.warning( f"Updated batch size to {self.__batch_size} as per server request" ) + if message.HasField("acks"): + with self.__acks_lock: + self.__inflight_objs.difference_update(message.acks.uuids) + self.__inflight_refs.difference_update(message.acks.beacons) if message.HasField("results"): result_objs = BatchObjectReturn() result_refs = BatchReferenceReturn() @@ -1159,11 +1193,23 @@ def __batch_recv(self) -> None: self.__results_for_wrapper.results.refs += result_refs self.__results_for_wrapper.failed_objects.extend(failed_objs) self.__results_for_wrapper.failed_references.extend(failed_refs) + elif message.HasField("out_of_memory"): + logger.warning( + "Server reported out-of-memory error. Batching will wait at most 10 minutes for the server to scale-up. If the server does not recover within this time, the batch will terminate with an error." + ) + self.__is_oom.set() + self.__batch_objects.prepend( + [self.__objs_cache[uuid] for uuid in message.out_of_memory.uuids] + ) + self.__batch_references.prepend( + [self.__refs_cache[beacon] for beacon in message.out_of_memory.beacons] + ) elif message.HasField("shutting_down"): logger.warning( "Received shutting down message from server, pausing sending until stream is re-established" ) self.__is_shutting_down.set() + self.__is_oom.clear() elif message.HasField("shutdown"): logger.warning("Received shutdown finished message from server") self.__is_shutdown.set() @@ -1181,16 +1227,17 @@ def __batch_recv(self) -> None: return def __reconnect(self, retry: int = 0) -> None: - if self.__consistency_level == ConsistencyLevel.ALL: + if self.__consistency_level == ConsistencyLevel.ALL or self.__number_of_nodes == 1: # check that all nodes are available before reconnecting - cluster = _ClusterBatch(self.__connection) - while len(nodes := cluster.get_nodes_status()) != 3 or any( - node["status"] != "HEALTHY" for node in nodes + up_nodes = self.__cluster.get_nodes_status() + while len(up_nodes) != self.__number_of_nodes or any( + node["status"] != "HEALTHY" for node in up_nodes ): logger.warning( - "Waiting for all nodes to be HEALTHY before reconnecting to batch stream due to CL=ALL..." + "Waiting for all nodes to be HEALTHY before reconnecting to batch stream..." ) time.sleep(5) + up_nodes = self.__cluster.get_nodes_status() try: logger.warning(f"Trying to reconnect after shutdown... {retry + 1}/{5}") self.__connection.close("sync") @@ -1223,8 +1270,12 @@ def batch_recv_wrapper() -> None: logger.warning("exited batch receive thread") except Exception as e: if isinstance(e, WeaviateBatchStreamError) and ( - "Socket closed" in e.message or "context canceled" in e.message + "Socket closed" in e.message + or "context canceled" in e.message + or "Connection reset" in e.message + or "Received RST_STREAM with error code 2" in e.message ): + logger.error(f"Socket hung up detected in batch receive thread: {e.message}") socket_hung_up = True else: logger.error(e) @@ -1241,19 +1292,9 @@ def batch_recv_wrapper() -> None: logger.warning( f"Re-adding {len(self.__objs_cache)} cached objects to the batch" ) - self.__batch_objects.prepend( - [ - self.__batch_grpc.grpc_object(o._to_internal()) - for o in self.__objs_cache.values() - ] - ) + self.__batch_objects.prepend(list(self.__objs_cache.values())) with self.__refs_cache_lock: - self.__batch_references.prepend( - [ - self.__batch_grpc.grpc_reference(o._to_internal()) - for o in self.__refs_cache.values() - ] - ) + self.__batch_references.prepend(list(self.__refs_cache.values())) # start a new stream with a newly reconnected channel return batch_recv_wrapper() @@ -1307,14 +1348,14 @@ def _add_object( uuid = str(batch_object.uuid) with self.__uuid_lookup_lock: self.__uuid_lookup.add(uuid) - self.__batch_objects.add(self.__batch_grpc.grpc_object(batch_object._to_internal())) + self.__batch_objects.add(batch_object) with self.__objs_cache_lock: self.__objs_cache[uuid] = batch_object self.__objs_count += 1 # block if queue gets too long or weaviate is overloaded - reading files is faster them sending them so we do # not need a long queue - while len(self.__batch_objects) >= self.__batch_size * 2: + while len(self.__inflight_objs) >= self.__batch_size: self.__check_bg_threads_alive() time.sleep(0.01) @@ -1352,12 +1393,13 @@ def _add_reference( ) except ValidationError as e: raise WeaviateBatchValidationError(repr(e)) - self.__batch_references.add( - self.__batch_grpc.grpc_reference(batch_reference._to_internal()) - ) + self.__batch_references.add(batch_reference) with self.__refs_cache_lock: self.__refs_cache[batch_reference._to_beacon()] = batch_reference self.__refs_count += 1 + while len(self.__inflight_refs) >= self.__batch_size * 2: + self.__check_bg_threads_alive() + time.sleep(0.01) def __check_bg_threads_alive(self) -> None: if self.__any_threads_alive(): @@ -1375,12 +1417,15 @@ def get_nodes_status( ) -> List[Node]: try: response = executor.result(self._connection.get(path="/nodes")) - except ConnectError as conn_err: - raise ConnectError("Get nodes status failed due to connection error") from conn_err + except Exception: + return [] response_typed = _decode_json_response_dict(response, "Nodes status") assert response_typed is not None nodes = response_typed.get("nodes") - if nodes is None or nodes == []: - raise EmptyResponseException("Nodes status response returned empty") + if nodes is None: + return [] return cast(List[Node], nodes) + + def get_number_of_nodes(self) -> int: + return len(self.get_nodes_status()) diff --git a/weaviate/connect/v4.py b/weaviate/connect/v4.py index 8c1f5f814..be7c0efbd 100644 --- a/weaviate/connect/v4.py +++ b/weaviate/connect/v4.py @@ -391,7 +391,7 @@ def _open_connections_rest( async def get_oidc() -> None: async with self._make_client("async") as client: try: - response = await client.get(oidc_url) + response = await client.get(oidc_url, timeout=self.timeout_config.init) except Exception as e: raise WeaviateConnectionError( f"Error: {e}. \nIs Weaviate running and reachable at {self.url}?" @@ -406,7 +406,7 @@ async def get_oidc() -> None: with self._make_client("sync") as client: try: - response = client.get(oidc_url) + response = client.get(oidc_url, timeout=self.timeout_config.init) except Exception as e: raise WeaviateConnectionError( f"Error: {e}. \nIs Weaviate running and reachable at {self.url}?" @@ -1013,7 +1013,7 @@ def grpc_batch_stream( raise InsufficientPermissionsError(error) if error.code() == StatusCode.ABORTED: raise _BatchStreamShutdownError() - raise WeaviateBatchStreamError(str(error.details())) + raise WeaviateBatchStreamError(f"{error.code()}({error.details()})") def grpc_batch_delete( self, request: batch_delete_pb2.BatchDeleteRequest diff --git a/weaviate/exceptions.py b/weaviate/exceptions.py index 5c6c771c9..2a5b429d5 100644 --- a/weaviate/exceptions.py +++ b/weaviate/exceptions.py @@ -292,6 +292,15 @@ def __init__(self, message: str): self.message = message +class WeaviateBatchFailedToReestablishStreamError(WeaviateBaseError): + """Is raised when the batch stream fails to re-establish within a timeout period.""" + + def __init__(self, message: str): + msg = f"""Batch stream failed to re-establish: {message}""" + super().__init__(msg) + self.message = message + + class WeaviateInsertInvalidPropertyError(WeaviateBaseError): """Is raised when inserting an invalid property.""" diff --git a/weaviate/proto/v1/v4216/v1/batch_pb2.py b/weaviate/proto/v1/v4216/v1/batch_pb2.py index ec84caf09..f45cfa621 100644 --- a/weaviate/proto/v1/v4216/v1/batch_pb2.py +++ b/weaviate/proto/v1/v4216/v1/batch_pb2.py @@ -15,7 +15,7 @@ from weaviate.proto.v1.v4216.v1 import base_pb2 as v1_dot_base__pb2 -DESCRIPTOR = _descriptor_pool.Default().AddSerializedFile(b'\n\x0ev1/batch.proto\x12\x0bweaviate.v1\x1a\x1cgoogle/protobuf/struct.proto\x1a\rv1/base.proto\"\x95\x01\n\x13\x42\x61tchObjectsRequest\x12)\n\x07objects\x18\x01 \x03(\x0b\x32\x18.weaviate.v1.BatchObject\x12=\n\x11\x63onsistency_level\x18\x02 \x01(\x0e\x32\x1d.weaviate.v1.ConsistencyLevelH\x00\x88\x01\x01\x42\x14\n\x12_consistency_level\"\x9e\x01\n\x16\x42\x61tchReferencesRequest\x12/\n\nreferences\x18\x01 \x03(\x0b\x32\x1b.weaviate.v1.BatchReference\x12=\n\x11\x63onsistency_level\x18\x02 \x01(\x0e\x32\x1d.weaviate.v1.ConsistencyLevelH\x00\x88\x01\x01\x42\x14\n\x12_consistency_level\"\xa6\x04\n\x12\x42\x61tchStreamRequest\x12\x36\n\x05start\x18\x01 \x01(\x0b\x32%.weaviate.v1.BatchStreamRequest.StartH\x00\x12\x34\n\x04\x64\x61ta\x18\x02 \x01(\x0b\x32$.weaviate.v1.BatchStreamRequest.DataH\x00\x12\x34\n\x04stop\x18\x03 \x01(\x0b\x32$.weaviate.v1.BatchStreamRequest.StopH\x00\x1a\\\n\x05Start\x12=\n\x11\x63onsistency_level\x18\x01 \x01(\x0e\x32\x1d.weaviate.v1.ConsistencyLevelH\x00\x88\x01\x01\x42\x14\n\x12_consistency_level\x1a\x06\n\x04Stop\x1a\xfa\x01\n\x04\x44\x61ta\x12=\n\x07objects\x18\x01 \x01(\x0b\x32,.weaviate.v1.BatchStreamRequest.Data.Objects\x12\x43\n\nreferences\x18\x02 \x01(\x0b\x32/.weaviate.v1.BatchStreamRequest.Data.References\x1a\x33\n\x07Objects\x12(\n\x06values\x18\x01 \x03(\x0b\x32\x18.weaviate.v1.BatchObject\x1a\x39\n\nReferences\x12+\n\x06values\x18\x01 \x03(\x0b\x32\x1b.weaviate.v1.BatchReferenceB\t\n\x07message\"\x98\x05\n\x10\x42\x61tchStreamReply\x12\x38\n\x07results\x18\x01 \x01(\x0b\x32%.weaviate.v1.BatchStreamReply.ResultsH\x00\x12\x43\n\rshutting_down\x18\x02 \x01(\x0b\x32*.weaviate.v1.BatchStreamReply.ShuttingDownH\x00\x12:\n\x08shutdown\x18\x03 \x01(\x0b\x32&.weaviate.v1.BatchStreamReply.ShutdownH\x00\x12\x38\n\x07started\x18\x04 \x01(\x0b\x32%.weaviate.v1.BatchStreamReply.StartedH\x00\x12\x38\n\x07\x62\x61\x63koff\x18\x05 \x01(\x0b\x32%.weaviate.v1.BatchStreamReply.BackoffH\x00\x1a\t\n\x07Started\x1a\x0e\n\x0cShuttingDown\x1a\n\n\x08Shutdown\x1a\x1d\n\x07\x42\x61\x63koff\x12\x12\n\nbatch_size\x18\x01 \x01(\x05\x1a\x83\x02\n\x07Results\x12;\n\x06\x65rrors\x18\x01 \x03(\x0b\x32+.weaviate.v1.BatchStreamReply.Results.Error\x12@\n\tsuccesses\x18\x02 \x03(\x0b\x32-.weaviate.v1.BatchStreamReply.Results.Success\x1a\x42\n\x05\x45rror\x12\r\n\x05\x65rror\x18\x01 \x01(\t\x12\x0e\n\x04uuid\x18\x02 \x01(\tH\x00\x12\x10\n\x06\x62\x65\x61\x63on\x18\x03 \x01(\tH\x00\x42\x08\n\x06\x64\x65tail\x1a\x35\n\x07Success\x12\x0e\n\x04uuid\x18\x02 \x01(\tH\x00\x12\x10\n\x06\x62\x65\x61\x63on\x18\x03 \x01(\tH\x00\x42\x08\n\x06\x64\x65tailB\t\n\x07message\"\xde\x07\n\x0b\x42\x61tchObject\x12\x0c\n\x04uuid\x18\x01 \x01(\t\x12\x12\n\x06vector\x18\x02 \x03(\x02\x42\x02\x18\x01\x12\x37\n\nproperties\x18\x03 \x01(\x0b\x32#.weaviate.v1.BatchObject.Properties\x12\x12\n\ncollection\x18\x04 \x01(\t\x12\x0e\n\x06tenant\x18\x05 \x01(\t\x12\x14\n\x0cvector_bytes\x18\x06 \x01(\x0c\x12%\n\x07vectors\x18\x17 \x03(\x0b\x32\x14.weaviate.v1.Vectors\x1a\x84\x05\n\nProperties\x12\x33\n\x12non_ref_properties\x18\x01 \x01(\x0b\x32\x17.google.protobuf.Struct\x12N\n\x17single_target_ref_props\x18\x02 \x03(\x0b\x32-.weaviate.v1.BatchObject.SingleTargetRefProps\x12L\n\x16multi_target_ref_props\x18\x03 \x03(\x0b\x32,.weaviate.v1.BatchObject.MultiTargetRefProps\x12\x43\n\x17number_array_properties\x18\x04 \x03(\x0b\x32\".weaviate.v1.NumberArrayProperties\x12=\n\x14int_array_properties\x18\x05 \x03(\x0b\x32\x1f.weaviate.v1.IntArrayProperties\x12?\n\x15text_array_properties\x18\x06 \x03(\x0b\x32 .weaviate.v1.TextArrayProperties\x12\x45\n\x18\x62oolean_array_properties\x18\x07 \x03(\x0b\x32#.weaviate.v1.BooleanArrayProperties\x12\x38\n\x11object_properties\x18\x08 \x03(\x0b\x32\x1d.weaviate.v1.ObjectProperties\x12\x43\n\x17object_array_properties\x18\t \x03(\x0b\x32\".weaviate.v1.ObjectArrayProperties\x12\x18\n\x10\x65mpty_list_props\x18\n \x03(\t\x1a\x38\n\x14SingleTargetRefProps\x12\r\n\x05uuids\x18\x01 \x03(\t\x12\x11\n\tprop_name\x18\x02 \x01(\t\x1aR\n\x13MultiTargetRefProps\x12\r\n\x05uuids\x18\x01 \x03(\t\x12\x11\n\tprop_name\x18\x02 \x01(\t\x12\x19\n\x11target_collection\x18\x03 \x01(\t\"\x99\x01\n\x0e\x42\x61tchReference\x12\x0c\n\x04name\x18\x01 \x01(\t\x12\x17\n\x0f\x66rom_collection\x18\x02 \x01(\t\x12\x11\n\tfrom_uuid\x18\x03 \x01(\t\x12\x1a\n\rto_collection\x18\x04 \x01(\tH\x00\x88\x01\x01\x12\x0f\n\x07to_uuid\x18\x05 \x01(\t\x12\x0e\n\x06tenant\x18\x06 \x01(\tB\x10\n\x0e_to_collection\"\x88\x01\n\x11\x42\x61tchObjectsReply\x12\x0c\n\x04took\x18\x01 \x01(\x02\x12\x39\n\x06\x65rrors\x18\x02 \x03(\x0b\x32).weaviate.v1.BatchObjectsReply.BatchError\x1a*\n\nBatchError\x12\r\n\x05index\x18\x01 \x01(\x05\x12\r\n\x05\x65rror\x18\x02 \x01(\t\"\x8e\x01\n\x14\x42\x61tchReferencesReply\x12\x0c\n\x04took\x18\x01 \x01(\x02\x12<\n\x06\x65rrors\x18\x02 \x03(\x0b\x32,.weaviate.v1.BatchReferencesReply.BatchError\x1a*\n\nBatchError\x12\r\n\x05index\x18\x01 \x01(\x05\x12\r\n\x05\x65rror\x18\x02 \x01(\tBo\n#io.weaviate.client.grpc.protocol.v1B\x12WeaviateProtoBatchZ4github.com/weaviate/weaviate/grpc/generated;protocolb\x06proto3') +DESCRIPTOR = _descriptor_pool.Default().AddSerializedFile(b'\n\x0ev1/batch.proto\x12\x0bweaviate.v1\x1a\x1cgoogle/protobuf/struct.proto\x1a\rv1/base.proto\"\x95\x01\n\x13\x42\x61tchObjectsRequest\x12)\n\x07objects\x18\x01 \x03(\x0b\x32\x18.weaviate.v1.BatchObject\x12=\n\x11\x63onsistency_level\x18\x02 \x01(\x0e\x32\x1d.weaviate.v1.ConsistencyLevelH\x00\x88\x01\x01\x42\x14\n\x12_consistency_level\"\x9e\x01\n\x16\x42\x61tchReferencesRequest\x12/\n\nreferences\x18\x01 \x03(\x0b\x32\x1b.weaviate.v1.BatchReference\x12=\n\x11\x63onsistency_level\x18\x02 \x01(\x0e\x32\x1d.weaviate.v1.ConsistencyLevelH\x00\x88\x01\x01\x42\x14\n\x12_consistency_level\"\xa6\x04\n\x12\x42\x61tchStreamRequest\x12\x36\n\x05start\x18\x01 \x01(\x0b\x32%.weaviate.v1.BatchStreamRequest.StartH\x00\x12\x34\n\x04\x64\x61ta\x18\x02 \x01(\x0b\x32$.weaviate.v1.BatchStreamRequest.DataH\x00\x12\x34\n\x04stop\x18\x03 \x01(\x0b\x32$.weaviate.v1.BatchStreamRequest.StopH\x00\x1a\\\n\x05Start\x12=\n\x11\x63onsistency_level\x18\x01 \x01(\x0e\x32\x1d.weaviate.v1.ConsistencyLevelH\x00\x88\x01\x01\x42\x14\n\x12_consistency_level\x1a\x06\n\x04Stop\x1a\xfa\x01\n\x04\x44\x61ta\x12=\n\x07objects\x18\x01 \x01(\x0b\x32,.weaviate.v1.BatchStreamRequest.Data.Objects\x12\x43\n\nreferences\x18\x02 \x01(\x0b\x32/.weaviate.v1.BatchStreamRequest.Data.References\x1a\x33\n\x07Objects\x12(\n\x06values\x18\x01 \x03(\x0b\x32\x18.weaviate.v1.BatchObject\x1a\x39\n\nReferences\x12+\n\x06values\x18\x01 \x03(\x0b\x32\x1b.weaviate.v1.BatchReferenceB\t\n\x07message\"\xe7\x06\n\x10\x42\x61tchStreamReply\x12\x38\n\x07results\x18\x01 \x01(\x0b\x32%.weaviate.v1.BatchStreamReply.ResultsH\x00\x12\x43\n\rshutting_down\x18\x02 \x01(\x0b\x32*.weaviate.v1.BatchStreamReply.ShuttingDownH\x00\x12:\n\x08shutdown\x18\x03 \x01(\x0b\x32&.weaviate.v1.BatchStreamReply.ShutdownH\x00\x12\x38\n\x07started\x18\x04 \x01(\x0b\x32%.weaviate.v1.BatchStreamReply.StartedH\x00\x12\x38\n\x07\x62\x61\x63koff\x18\x05 \x01(\x0b\x32%.weaviate.v1.BatchStreamReply.BackoffH\x00\x12\x32\n\x04\x61\x63ks\x18\x06 \x01(\x0b\x32\".weaviate.v1.BatchStreamReply.AcksH\x00\x12\x42\n\rout_of_memory\x18\x07 \x01(\x0b\x32).weaviate.v1.BatchStreamReply.OutOfMemoryH\x00\x1a\t\n\x07Started\x1a\x0e\n\x0cShuttingDown\x1a\n\n\x08Shutdown\x1a-\n\x0bOutOfMemory\x12\r\n\x05uuids\x18\x01 \x03(\t\x12\x0f\n\x07\x62\x65\x61\x63ons\x18\x02 \x03(\t\x1a\x1d\n\x07\x42\x61\x63koff\x12\x12\n\nbatch_size\x18\x01 \x01(\x05\x1a&\n\x04\x41\x63ks\x12\r\n\x05uuids\x18\x01 \x03(\t\x12\x0f\n\x07\x62\x65\x61\x63ons\x18\x02 \x03(\t\x1a\x83\x02\n\x07Results\x12;\n\x06\x65rrors\x18\x01 \x03(\x0b\x32+.weaviate.v1.BatchStreamReply.Results.Error\x12@\n\tsuccesses\x18\x02 \x03(\x0b\x32-.weaviate.v1.BatchStreamReply.Results.Success\x1a\x42\n\x05\x45rror\x12\r\n\x05\x65rror\x18\x01 \x01(\t\x12\x0e\n\x04uuid\x18\x02 \x01(\tH\x00\x12\x10\n\x06\x62\x65\x61\x63on\x18\x03 \x01(\tH\x00\x42\x08\n\x06\x64\x65tail\x1a\x35\n\x07Success\x12\x0e\n\x04uuid\x18\x02 \x01(\tH\x00\x12\x10\n\x06\x62\x65\x61\x63on\x18\x03 \x01(\tH\x00\x42\x08\n\x06\x64\x65tailB\t\n\x07message\"\xde\x07\n\x0b\x42\x61tchObject\x12\x0c\n\x04uuid\x18\x01 \x01(\t\x12\x12\n\x06vector\x18\x02 \x03(\x02\x42\x02\x18\x01\x12\x37\n\nproperties\x18\x03 \x01(\x0b\x32#.weaviate.v1.BatchObject.Properties\x12\x12\n\ncollection\x18\x04 \x01(\t\x12\x0e\n\x06tenant\x18\x05 \x01(\t\x12\x14\n\x0cvector_bytes\x18\x06 \x01(\x0c\x12%\n\x07vectors\x18\x17 \x03(\x0b\x32\x14.weaviate.v1.Vectors\x1a\x84\x05\n\nProperties\x12\x33\n\x12non_ref_properties\x18\x01 \x01(\x0b\x32\x17.google.protobuf.Struct\x12N\n\x17single_target_ref_props\x18\x02 \x03(\x0b\x32-.weaviate.v1.BatchObject.SingleTargetRefProps\x12L\n\x16multi_target_ref_props\x18\x03 \x03(\x0b\x32,.weaviate.v1.BatchObject.MultiTargetRefProps\x12\x43\n\x17number_array_properties\x18\x04 \x03(\x0b\x32\".weaviate.v1.NumberArrayProperties\x12=\n\x14int_array_properties\x18\x05 \x03(\x0b\x32\x1f.weaviate.v1.IntArrayProperties\x12?\n\x15text_array_properties\x18\x06 \x03(\x0b\x32 .weaviate.v1.TextArrayProperties\x12\x45\n\x18\x62oolean_array_properties\x18\x07 \x03(\x0b\x32#.weaviate.v1.BooleanArrayProperties\x12\x38\n\x11object_properties\x18\x08 \x03(\x0b\x32\x1d.weaviate.v1.ObjectProperties\x12\x43\n\x17object_array_properties\x18\t \x03(\x0b\x32\".weaviate.v1.ObjectArrayProperties\x12\x18\n\x10\x65mpty_list_props\x18\n \x03(\t\x1a\x38\n\x14SingleTargetRefProps\x12\r\n\x05uuids\x18\x01 \x03(\t\x12\x11\n\tprop_name\x18\x02 \x01(\t\x1aR\n\x13MultiTargetRefProps\x12\r\n\x05uuids\x18\x01 \x03(\t\x12\x11\n\tprop_name\x18\x02 \x01(\t\x12\x19\n\x11target_collection\x18\x03 \x01(\t\"\x99\x01\n\x0e\x42\x61tchReference\x12\x0c\n\x04name\x18\x01 \x01(\t\x12\x17\n\x0f\x66rom_collection\x18\x02 \x01(\t\x12\x11\n\tfrom_uuid\x18\x03 \x01(\t\x12\x1a\n\rto_collection\x18\x04 \x01(\tH\x00\x88\x01\x01\x12\x0f\n\x07to_uuid\x18\x05 \x01(\t\x12\x0e\n\x06tenant\x18\x06 \x01(\tB\x10\n\x0e_to_collection\"\x88\x01\n\x11\x42\x61tchObjectsReply\x12\x0c\n\x04took\x18\x01 \x01(\x02\x12\x39\n\x06\x65rrors\x18\x02 \x03(\x0b\x32).weaviate.v1.BatchObjectsReply.BatchError\x1a*\n\nBatchError\x12\r\n\x05index\x18\x01 \x01(\x05\x12\r\n\x05\x65rror\x18\x02 \x01(\t\"\x8e\x01\n\x14\x42\x61tchReferencesReply\x12\x0c\n\x04took\x18\x01 \x01(\x02\x12<\n\x06\x65rrors\x18\x02 \x03(\x0b\x32,.weaviate.v1.BatchReferencesReply.BatchError\x1a*\n\nBatchError\x12\r\n\x05index\x18\x01 \x01(\x05\x12\r\n\x05\x65rror\x18\x02 \x01(\tBo\n#io.weaviate.client.grpc.protocol.v1B\x12WeaviateProtoBatchZ4github.com/weaviate/weaviate/grpc/generated;protocolb\x06proto3') _globals = globals() _builder.BuildMessageAndEnumDescriptors(DESCRIPTOR, _globals) @@ -42,37 +42,41 @@ _globals['_BATCHSTREAMREQUEST_DATA_REFERENCES']._serialized_start=872 _globals['_BATCHSTREAMREQUEST_DATA_REFERENCES']._serialized_end=929 _globals['_BATCHSTREAMREPLY']._serialized_start=943 - _globals['_BATCHSTREAMREPLY']._serialized_end=1607 - _globals['_BATCHSTREAMREPLY_STARTED']._serialized_start=1266 - _globals['_BATCHSTREAMREPLY_STARTED']._serialized_end=1275 - _globals['_BATCHSTREAMREPLY_SHUTTINGDOWN']._serialized_start=1277 - _globals['_BATCHSTREAMREPLY_SHUTTINGDOWN']._serialized_end=1291 - _globals['_BATCHSTREAMREPLY_SHUTDOWN']._serialized_start=1293 - _globals['_BATCHSTREAMREPLY_SHUTDOWN']._serialized_end=1303 - _globals['_BATCHSTREAMREPLY_BACKOFF']._serialized_start=1305 - _globals['_BATCHSTREAMREPLY_BACKOFF']._serialized_end=1334 - _globals['_BATCHSTREAMREPLY_RESULTS']._serialized_start=1337 - _globals['_BATCHSTREAMREPLY_RESULTS']._serialized_end=1596 - _globals['_BATCHSTREAMREPLY_RESULTS_ERROR']._serialized_start=1475 - _globals['_BATCHSTREAMREPLY_RESULTS_ERROR']._serialized_end=1541 - _globals['_BATCHSTREAMREPLY_RESULTS_SUCCESS']._serialized_start=1543 - _globals['_BATCHSTREAMREPLY_RESULTS_SUCCESS']._serialized_end=1596 - _globals['_BATCHOBJECT']._serialized_start=1610 - _globals['_BATCHOBJECT']._serialized_end=2600 - _globals['_BATCHOBJECT_PROPERTIES']._serialized_start=1814 - _globals['_BATCHOBJECT_PROPERTIES']._serialized_end=2458 - _globals['_BATCHOBJECT_SINGLETARGETREFPROPS']._serialized_start=2460 - _globals['_BATCHOBJECT_SINGLETARGETREFPROPS']._serialized_end=2516 - _globals['_BATCHOBJECT_MULTITARGETREFPROPS']._serialized_start=2518 - _globals['_BATCHOBJECT_MULTITARGETREFPROPS']._serialized_end=2600 - _globals['_BATCHREFERENCE']._serialized_start=2603 - _globals['_BATCHREFERENCE']._serialized_end=2756 - _globals['_BATCHOBJECTSREPLY']._serialized_start=2759 - _globals['_BATCHOBJECTSREPLY']._serialized_end=2895 - _globals['_BATCHOBJECTSREPLY_BATCHERROR']._serialized_start=2853 - _globals['_BATCHOBJECTSREPLY_BATCHERROR']._serialized_end=2895 - _globals['_BATCHREFERENCESREPLY']._serialized_start=2898 - _globals['_BATCHREFERENCESREPLY']._serialized_end=3040 - _globals['_BATCHREFERENCESREPLY_BATCHERROR']._serialized_start=2853 - _globals['_BATCHREFERENCESREPLY_BATCHERROR']._serialized_end=2895 + _globals['_BATCHSTREAMREPLY']._serialized_end=1814 + _globals['_BATCHSTREAMREPLY_STARTED']._serialized_start=1386 + _globals['_BATCHSTREAMREPLY_STARTED']._serialized_end=1395 + _globals['_BATCHSTREAMREPLY_SHUTTINGDOWN']._serialized_start=1397 + _globals['_BATCHSTREAMREPLY_SHUTTINGDOWN']._serialized_end=1411 + _globals['_BATCHSTREAMREPLY_SHUTDOWN']._serialized_start=1413 + _globals['_BATCHSTREAMREPLY_SHUTDOWN']._serialized_end=1423 + _globals['_BATCHSTREAMREPLY_OUTOFMEMORY']._serialized_start=1425 + _globals['_BATCHSTREAMREPLY_OUTOFMEMORY']._serialized_end=1470 + _globals['_BATCHSTREAMREPLY_BACKOFF']._serialized_start=1472 + _globals['_BATCHSTREAMREPLY_BACKOFF']._serialized_end=1501 + _globals['_BATCHSTREAMREPLY_ACKS']._serialized_start=1503 + _globals['_BATCHSTREAMREPLY_ACKS']._serialized_end=1541 + _globals['_BATCHSTREAMREPLY_RESULTS']._serialized_start=1544 + _globals['_BATCHSTREAMREPLY_RESULTS']._serialized_end=1803 + _globals['_BATCHSTREAMREPLY_RESULTS_ERROR']._serialized_start=1682 + _globals['_BATCHSTREAMREPLY_RESULTS_ERROR']._serialized_end=1748 + _globals['_BATCHSTREAMREPLY_RESULTS_SUCCESS']._serialized_start=1750 + _globals['_BATCHSTREAMREPLY_RESULTS_SUCCESS']._serialized_end=1803 + _globals['_BATCHOBJECT']._serialized_start=1817 + _globals['_BATCHOBJECT']._serialized_end=2807 + _globals['_BATCHOBJECT_PROPERTIES']._serialized_start=2021 + _globals['_BATCHOBJECT_PROPERTIES']._serialized_end=2665 + _globals['_BATCHOBJECT_SINGLETARGETREFPROPS']._serialized_start=2667 + _globals['_BATCHOBJECT_SINGLETARGETREFPROPS']._serialized_end=2723 + _globals['_BATCHOBJECT_MULTITARGETREFPROPS']._serialized_start=2725 + _globals['_BATCHOBJECT_MULTITARGETREFPROPS']._serialized_end=2807 + _globals['_BATCHREFERENCE']._serialized_start=2810 + _globals['_BATCHREFERENCE']._serialized_end=2963 + _globals['_BATCHOBJECTSREPLY']._serialized_start=2966 + _globals['_BATCHOBJECTSREPLY']._serialized_end=3102 + _globals['_BATCHOBJECTSREPLY_BATCHERROR']._serialized_start=3060 + _globals['_BATCHOBJECTSREPLY_BATCHERROR']._serialized_end=3102 + _globals['_BATCHREFERENCESREPLY']._serialized_start=3105 + _globals['_BATCHREFERENCESREPLY']._serialized_end=3247 + _globals['_BATCHREFERENCESREPLY_BATCHERROR']._serialized_start=3060 + _globals['_BATCHREFERENCESREPLY_BATCHERROR']._serialized_end=3102 # @@protoc_insertion_point(module_scope) diff --git a/weaviate/proto/v1/v4216/v1/batch_pb2.pyi b/weaviate/proto/v1/v4216/v1/batch_pb2.pyi index 17ef5a965..a0ada063c 100644 --- a/weaviate/proto/v1/v4216/v1/batch_pb2.pyi +++ b/weaviate/proto/v1/v4216/v1/batch_pb2.pyi @@ -59,7 +59,7 @@ class BatchStreamRequest(_message.Message): def __init__(self, start: _Optional[_Union[BatchStreamRequest.Start, _Mapping]] = ..., data: _Optional[_Union[BatchStreamRequest.Data, _Mapping]] = ..., stop: _Optional[_Union[BatchStreamRequest.Stop, _Mapping]] = ...) -> None: ... class BatchStreamReply(_message.Message): - __slots__ = ["results", "shutting_down", "shutdown", "started", "backoff"] + __slots__ = ["results", "shutting_down", "shutdown", "started", "backoff", "acks", "out_of_memory"] class Started(_message.Message): __slots__ = [] def __init__(self) -> None: ... @@ -69,11 +69,25 @@ class BatchStreamReply(_message.Message): class Shutdown(_message.Message): __slots__ = [] def __init__(self) -> None: ... + class OutOfMemory(_message.Message): + __slots__ = ["uuids", "beacons"] + UUIDS_FIELD_NUMBER: _ClassVar[int] + BEACONS_FIELD_NUMBER: _ClassVar[int] + uuids: _containers.RepeatedScalarFieldContainer[str] + beacons: _containers.RepeatedScalarFieldContainer[str] + def __init__(self, uuids: _Optional[_Iterable[str]] = ..., beacons: _Optional[_Iterable[str]] = ...) -> None: ... class Backoff(_message.Message): __slots__ = ["batch_size"] BATCH_SIZE_FIELD_NUMBER: _ClassVar[int] batch_size: int def __init__(self, batch_size: _Optional[int] = ...) -> None: ... + class Acks(_message.Message): + __slots__ = ["uuids", "beacons"] + UUIDS_FIELD_NUMBER: _ClassVar[int] + BEACONS_FIELD_NUMBER: _ClassVar[int] + uuids: _containers.RepeatedScalarFieldContainer[str] + beacons: _containers.RepeatedScalarFieldContainer[str] + def __init__(self, uuids: _Optional[_Iterable[str]] = ..., beacons: _Optional[_Iterable[str]] = ...) -> None: ... class Results(_message.Message): __slots__ = ["errors", "successes"] class Error(_message.Message): @@ -102,12 +116,16 @@ class BatchStreamReply(_message.Message): SHUTDOWN_FIELD_NUMBER: _ClassVar[int] STARTED_FIELD_NUMBER: _ClassVar[int] BACKOFF_FIELD_NUMBER: _ClassVar[int] + ACKS_FIELD_NUMBER: _ClassVar[int] + OUT_OF_MEMORY_FIELD_NUMBER: _ClassVar[int] results: BatchStreamReply.Results shutting_down: BatchStreamReply.ShuttingDown shutdown: BatchStreamReply.Shutdown started: BatchStreamReply.Started backoff: BatchStreamReply.Backoff - def __init__(self, results: _Optional[_Union[BatchStreamReply.Results, _Mapping]] = ..., shutting_down: _Optional[_Union[BatchStreamReply.ShuttingDown, _Mapping]] = ..., shutdown: _Optional[_Union[BatchStreamReply.Shutdown, _Mapping]] = ..., started: _Optional[_Union[BatchStreamReply.Started, _Mapping]] = ..., backoff: _Optional[_Union[BatchStreamReply.Backoff, _Mapping]] = ...) -> None: ... + acks: BatchStreamReply.Acks + out_of_memory: BatchStreamReply.OutOfMemory + def __init__(self, results: _Optional[_Union[BatchStreamReply.Results, _Mapping]] = ..., shutting_down: _Optional[_Union[BatchStreamReply.ShuttingDown, _Mapping]] = ..., shutdown: _Optional[_Union[BatchStreamReply.Shutdown, _Mapping]] = ..., started: _Optional[_Union[BatchStreamReply.Started, _Mapping]] = ..., backoff: _Optional[_Union[BatchStreamReply.Backoff, _Mapping]] = ..., acks: _Optional[_Union[BatchStreamReply.Acks, _Mapping]] = ..., out_of_memory: _Optional[_Union[BatchStreamReply.OutOfMemory, _Mapping]] = ...) -> None: ... class BatchObject(_message.Message): __slots__ = ["uuid", "vector", "properties", "collection", "tenant", "vector_bytes", "vectors"] diff --git a/weaviate/proto/v1/v4216/v1/generative_pb2.py b/weaviate/proto/v1/v4216/v1/generative_pb2.py index 139e0b8a7..46bef0181 100644 --- a/weaviate/proto/v1/v4216/v1/generative_pb2.py +++ b/weaviate/proto/v1/v4216/v1/generative_pb2.py @@ -14,7 +14,7 @@ from weaviate.proto.v1.v4216.v1 import base_pb2 as v1_dot_base__pb2 -DESCRIPTOR = _descriptor_pool.Default().AddSerializedFile(b'\n\x13v1/generative.proto\x12\x0bweaviate.v1\x1a\rv1/base.proto\"\xdd\x03\n\x10GenerativeSearch\x12\"\n\x16single_response_prompt\x18\x01 \x01(\tB\x02\x18\x01\x12!\n\x15grouped_response_task\x18\x02 \x01(\tB\x02\x18\x01\x12\x1e\n\x12grouped_properties\x18\x03 \x03(\tB\x02\x18\x01\x12\x34\n\x06single\x18\x04 \x01(\x0b\x32$.weaviate.v1.GenerativeSearch.Single\x12\x36\n\x07grouped\x18\x05 \x01(\x0b\x32%.weaviate.v1.GenerativeSearch.Grouped\x1aY\n\x06Single\x12\x0e\n\x06prompt\x18\x01 \x01(\t\x12\r\n\x05\x64\x65\x62ug\x18\x02 \x01(\x08\x12\x30\n\x07queries\x18\x03 \x03(\x0b\x32\x1f.weaviate.v1.GenerativeProvider\x1a\x98\x01\n\x07Grouped\x12\x0c\n\x04task\x18\x01 \x01(\t\x12/\n\nproperties\x18\x02 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x00\x88\x01\x01\x12\x30\n\x07queries\x18\x03 \x03(\x0b\x32\x1f.weaviate.v1.GenerativeProvider\x12\r\n\x05\x64\x65\x62ug\x18\x04 \x01(\x08\x42\r\n\x0b_properties\"\xfd\x05\n\x12GenerativeProvider\x12\x17\n\x0freturn_metadata\x18\x01 \x01(\x08\x12\x35\n\tanthropic\x18\x02 \x01(\x0b\x32 .weaviate.v1.GenerativeAnthropicH\x00\x12\x33\n\x08\x61nyscale\x18\x03 \x01(\x0b\x32\x1f.weaviate.v1.GenerativeAnyscaleH\x00\x12)\n\x03\x61ws\x18\x04 \x01(\x0b\x32\x1a.weaviate.v1.GenerativeAWSH\x00\x12/\n\x06\x63ohere\x18\x05 \x01(\x0b\x32\x1d.weaviate.v1.GenerativeCohereH\x00\x12-\n\x05\x64ummy\x18\x06 \x01(\x0b\x32\x1c.weaviate.v1.GenerativeDummyH\x00\x12\x31\n\x07mistral\x18\x07 \x01(\x0b\x32\x1e.weaviate.v1.GenerativeMistralH\x00\x12/\n\x06ollama\x18\x08 \x01(\x0b\x32\x1d.weaviate.v1.GenerativeOllamaH\x00\x12/\n\x06openai\x18\t \x01(\x0b\x32\x1d.weaviate.v1.GenerativeOpenAIH\x00\x12/\n\x06google\x18\n \x01(\x0b\x32\x1d.weaviate.v1.GenerativeGoogleH\x00\x12\x37\n\ndatabricks\x18\x0b \x01(\x0b\x32!.weaviate.v1.GenerativeDatabricksH\x00\x12\x37\n\nfriendliai\x18\x0c \x01(\x0b\x32!.weaviate.v1.GenerativeFriendliAIH\x00\x12/\n\x06nvidia\x18\r \x01(\x0b\x32\x1d.weaviate.v1.GenerativeNvidiaH\x00\x12)\n\x03xai\x18\x0e \x01(\x0b\x32\x1a.weaviate.v1.GenerativeXAIH\x00\x12;\n\x0c\x63ontextualai\x18\x0f \x01(\x0b\x32#.weaviate.v1.GenerativeContextualAIH\x00\x42\x06\n\x04kind\"\xb1\x03\n\x13GenerativeAnthropic\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x18\n\x0btemperature\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x12\n\x05top_k\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x12\n\x05top_p\x18\x06 \x01(\x01H\x05\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x07 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x06\x88\x01\x01\x12+\n\x06images\x18\x08 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x35\n\x10image_properties\x18\t \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x08\x88\x01\x01\x42\x0b\n\t_base_urlB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_kB\x08\n\x06_top_pB\x11\n\x0f_stop_sequencesB\t\n\x07_imagesB\x13\n\x11_image_properties\"\x80\x01\n\x12GenerativeAnyscale\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\x0e\n\x0c_temperature\"\xc5\x03\n\rGenerativeAWS\x12\x12\n\x05model\x18\x03 \x01(\tH\x00\x88\x01\x01\x12\x18\n\x0btemperature\x18\x08 \x01(\x01H\x01\x88\x01\x01\x12\x14\n\x07service\x18\t \x01(\tH\x02\x88\x01\x01\x12\x13\n\x06region\x18\n \x01(\tH\x03\x88\x01\x01\x12\x15\n\x08\x65ndpoint\x18\x0b \x01(\tH\x04\x88\x01\x01\x12\x19\n\x0ctarget_model\x18\x0c \x01(\tH\x05\x88\x01\x01\x12\x1b\n\x0etarget_variant\x18\r \x01(\tH\x06\x88\x01\x01\x12+\n\x06images\x18\x0e \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0f \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x08\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x10 \x01(\x03H\t\x88\x01\x01\x42\x08\n\x06_modelB\x0e\n\x0c_temperatureB\n\n\x08_serviceB\t\n\x07_regionB\x0b\n\t_endpointB\x0f\n\r_target_modelB\x11\n\x0f_target_variantB\t\n\x07_imagesB\x13\n\x11_image_propertiesB\r\n\x0b_max_tokens\"\x88\x04\n\x10GenerativeCohere\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x1e\n\x11\x66requency_penalty\x18\x02 \x01(\x01H\x01\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x12\x12\n\x05model\x18\x04 \x01(\tH\x03\x88\x01\x01\x12\x0e\n\x01k\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x0e\n\x01p\x18\x06 \x01(\x01H\x05\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x07 \x01(\x01H\x06\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x08 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x18\n\x0btemperature\x18\t \x01(\x01H\x08\x88\x01\x01\x12+\n\x06images\x18\n \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\t\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0b \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\n\x88\x01\x01\x42\x0b\n\t_base_urlB\x14\n\x12_frequency_penaltyB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x04\n\x02_kB\x04\n\x02_pB\x13\n\x11_presence_penaltyB\x11\n\x0f_stop_sequencesB\x0e\n\x0c_temperatureB\t\n\x07_imagesB\x13\n\x11_image_properties\"\x11\n\x0fGenerativeDummy\"\xc5\x01\n\x11GenerativeMistral\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x18\n\x0btemperature\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x12\n\x05top_p\x18\x05 \x01(\x01H\x04\x88\x01\x01\x42\x0b\n\t_base_urlB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_p\"\x8a\x02\n\x10GenerativeOllama\x12\x19\n\x0c\x61pi_endpoint\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12+\n\x06images\x18\x04 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x03\x88\x01\x01\x12\x35\n\x10image_properties\x18\x05 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x04\x88\x01\x01\x42\x0f\n\r_api_endpointB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\t\n\x07_imagesB\x13\n\x11_image_properties\"\xe3\x08\n\x10GenerativeOpenAI\x12\x1e\n\x11\x66requency_penalty\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x0e\n\x01n\x18\x04 \x01(\x03H\x03\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x05 \x01(\x01H\x04\x88\x01\x01\x12)\n\x04stop\x18\x06 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x05\x88\x01\x01\x12\x18\n\x0btemperature\x18\x07 \x01(\x01H\x06\x88\x01\x01\x12\x12\n\x05top_p\x18\x08 \x01(\x01H\x07\x88\x01\x01\x12\x15\n\x08\x62\x61se_url\x18\t \x01(\tH\x08\x88\x01\x01\x12\x18\n\x0b\x61pi_version\x18\n \x01(\tH\t\x88\x01\x01\x12\x1a\n\rresource_name\x18\x0b \x01(\tH\n\x88\x01\x01\x12\x1a\n\rdeployment_id\x18\x0c \x01(\tH\x0b\x88\x01\x01\x12\x15\n\x08is_azure\x18\r \x01(\x08H\x0c\x88\x01\x01\x12+\n\x06images\x18\x0e \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\r\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0f \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x0e\x88\x01\x01\x12L\n\x10reasoning_effort\x18\x10 \x01(\x0e\x32-.weaviate.v1.GenerativeOpenAI.ReasoningEffortH\x0f\x88\x01\x01\x12?\n\tverbosity\x18\x11 \x01(\x0e\x32\'.weaviate.v1.GenerativeOpenAI.VerbosityH\x10\x88\x01\x01\"\xa3\x01\n\x0fReasoningEffort\x12 \n\x1cREASONING_EFFORT_UNSPECIFIED\x10\x00\x12\x1c\n\x18REASONING_EFFORT_MINIMAL\x10\x01\x12\x18\n\x14REASONING_EFFORT_LOW\x10\x02\x12\x1b\n\x17REASONING_EFFORT_MEDIUM\x10\x03\x12\x19\n\x15REASONING_EFFORT_HIGH\x10\x04\"c\n\tVerbosity\x12\x19\n\x15VERBOSITY_UNSPECIFIED\x10\x00\x12\x11\n\rVERBOSITY_LOW\x10\x01\x12\x14\n\x10VERBOSITY_MEDIUM\x10\x02\x12\x12\n\x0eVERBOSITY_HIGH\x10\x03\x42\x14\n\x12_frequency_penaltyB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x04\n\x02_nB\x13\n\x11_presence_penaltyB\x07\n\x05_stopB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\x0b\n\t_base_urlB\x0e\n\x0c_api_versionB\x10\n\x0e_resource_nameB\x10\n\x0e_deployment_idB\x0b\n\t_is_azureB\t\n\x07_imagesB\x13\n\x11_image_propertiesB\x13\n\x11_reasoning_effortB\x0c\n\n_verbosity\"\x92\x05\n\x10GenerativeGoogle\x12\x1e\n\x11\x66requency_penalty\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x18\n\x0btemperature\x18\x05 \x01(\x01H\x04\x88\x01\x01\x12\x12\n\x05top_k\x18\x06 \x01(\x03H\x05\x88\x01\x01\x12\x12\n\x05top_p\x18\x07 \x01(\x01H\x06\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x08 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x19\n\x0c\x61pi_endpoint\x18\t \x01(\tH\x08\x88\x01\x01\x12\x17\n\nproject_id\x18\n \x01(\tH\t\x88\x01\x01\x12\x18\n\x0b\x65ndpoint_id\x18\x0b \x01(\tH\n\x88\x01\x01\x12\x13\n\x06region\x18\x0c \x01(\tH\x0b\x88\x01\x01\x12+\n\x06images\x18\r \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x0c\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0e \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\r\x88\x01\x01\x42\x14\n\x12_frequency_penaltyB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x13\n\x11_presence_penaltyB\x0e\n\x0c_temperatureB\x08\n\x06_top_kB\x08\n\x06_top_pB\x11\n\x0f_stop_sequencesB\x0f\n\r_api_endpointB\r\n\x0b_project_idB\x0e\n\x0c_endpoint_idB\t\n\x07_regionB\t\n\x07_imagesB\x13\n\x11_image_properties\"\xd0\x03\n\x14GenerativeDatabricks\x12\x15\n\x08\x65ndpoint\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x1e\n\x11\x66requency_penalty\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x16\n\tlog_probs\x18\x04 \x01(\x08H\x03\x88\x01\x01\x12\x1a\n\rtop_log_probs\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x06 \x01(\x03H\x05\x88\x01\x01\x12\x0e\n\x01n\x18\x07 \x01(\x03H\x06\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x08 \x01(\x01H\x07\x88\x01\x01\x12)\n\x04stop\x18\t \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x08\x88\x01\x01\x12\x18\n\x0btemperature\x18\n \x01(\x01H\t\x88\x01\x01\x12\x12\n\x05top_p\x18\x0b \x01(\x01H\n\x88\x01\x01\x42\x0b\n\t_endpointB\x08\n\x06_modelB\x14\n\x12_frequency_penaltyB\x0c\n\n_log_probsB\x10\n\x0e_top_log_probsB\r\n\x0b_max_tokensB\x04\n\x02_nB\x13\n\x11_presence_penaltyB\x07\n\x05_stopB\x0e\n\x0c_temperatureB\x08\n\x06_top_p\"\xde\x01\n\x14GenerativeFriendliAI\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x12\x18\n\x0btemperature\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x0e\n\x01n\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x12\n\x05top_p\x18\x06 \x01(\x01H\x05\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\r\n\x0b_max_tokensB\x0e\n\x0c_temperatureB\x04\n\x02_nB\x08\n\x06_top_p\"\xc4\x01\n\x10GenerativeNvidia\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x12\n\x05top_p\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x05 \x01(\x03H\x04\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\r\n\x0b_max_tokens\"\xc5\x02\n\rGenerativeXAI\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x12\n\x05top_p\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12+\n\x06images\x18\x06 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x05\x88\x01\x01\x12\x35\n\x10image_properties\x18\x07 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x06\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\r\n\x0b_max_tokensB\t\n\x07_imagesB\x13\n\x11_image_properties\"\xce\x02\n\x16GenerativeContextualAI\x12\x12\n\x05model\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x18\n\x0btemperature\x18\x02 \x01(\x01H\x01\x88\x01\x01\x12\x12\n\x05top_p\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x1b\n\x0emax_new_tokens\x18\x04 \x01(\x03H\x03\x88\x01\x01\x12\x1a\n\rsystem_prompt\x18\x05 \x01(\tH\x04\x88\x01\x01\x12\x1d\n\x10\x61void_commentary\x18\x06 \x01(\x08H\x05\x88\x01\x01\x12.\n\tknowledge\x18\x07 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x06\x88\x01\x01\x42\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\x11\n\x0f_max_new_tokensB\x10\n\x0e_system_promptB\x13\n\x11_avoid_commentaryB\x0c\n\n_knowledge\"\x92\x01\n\x1bGenerativeAnthropicMetadata\x12=\n\x05usage\x18\x01 \x01(\x0b\x32..weaviate.v1.GenerativeAnthropicMetadata.Usage\x1a\x34\n\x05Usage\x12\x14\n\x0cinput_tokens\x18\x01 \x01(\x03\x12\x15\n\routput_tokens\x18\x02 \x01(\x03\"\x1c\n\x1aGenerativeAnyscaleMetadata\"\x17\n\x15GenerativeAWSMetadata\"\x9c\x06\n\x18GenerativeCohereMetadata\x12J\n\x0b\x61pi_version\x18\x01 \x01(\x0b\x32\x30.weaviate.v1.GenerativeCohereMetadata.ApiVersionH\x00\x88\x01\x01\x12L\n\x0c\x62illed_units\x18\x02 \x01(\x0b\x32\x31.weaviate.v1.GenerativeCohereMetadata.BilledUnitsH\x01\x88\x01\x01\x12\x41\n\x06tokens\x18\x03 \x01(\x0b\x32,.weaviate.v1.GenerativeCohereMetadata.TokensH\x02\x88\x01\x01\x12-\n\x08warnings\x18\x04 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x03\x88\x01\x01\x1a\x8e\x01\n\nApiVersion\x12\x14\n\x07version\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x1a\n\ris_deprecated\x18\x02 \x01(\x08H\x01\x88\x01\x01\x12\x1c\n\x0fis_experimental\x18\x03 \x01(\x08H\x02\x88\x01\x01\x42\n\n\x08_versionB\x10\n\x0e_is_deprecatedB\x12\n\x10_is_experimental\x1a\xc5\x01\n\x0b\x42illedUnits\x12\x19\n\x0cinput_tokens\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x1a\n\routput_tokens\x18\x02 \x01(\x01H\x01\x88\x01\x01\x12\x19\n\x0csearch_units\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x1c\n\x0f\x63lassifications\x18\x04 \x01(\x01H\x03\x88\x01\x01\x42\x0f\n\r_input_tokensB\x10\n\x0e_output_tokensB\x0f\n\r_search_unitsB\x12\n\x10_classifications\x1a\x62\n\x06Tokens\x12\x19\n\x0cinput_tokens\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x1a\n\routput_tokens\x18\x02 \x01(\x01H\x01\x88\x01\x01\x42\x0f\n\r_input_tokensB\x10\n\x0e_output_tokensB\x0e\n\x0c_api_versionB\x0f\n\r_billed_unitsB\t\n\x07_tokensB\x0b\n\t_warnings\"\x19\n\x17GenerativeDummyMetadata\"\x81\x02\n\x19GenerativeMistralMetadata\x12@\n\x05usage\x18\x01 \x01(\x0b\x32,.weaviate.v1.GenerativeMistralMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\x1a\n\x18GenerativeOllamaMetadata\"\xff\x01\n\x18GenerativeOpenAIMetadata\x12?\n\x05usage\x18\x01 \x01(\x0b\x32+.weaviate.v1.GenerativeOpenAIMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\xe8\x06\n\x18GenerativeGoogleMetadata\x12\x45\n\x08metadata\x18\x01 \x01(\x0b\x32..weaviate.v1.GenerativeGoogleMetadata.MetadataH\x00\x88\x01\x01\x12P\n\x0eusage_metadata\x18\x02 \x01(\x0b\x32\x33.weaviate.v1.GenerativeGoogleMetadata.UsageMetadataH\x01\x88\x01\x01\x1a~\n\nTokenCount\x12&\n\x19total_billable_characters\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x42\x1c\n\x1a_total_billable_charactersB\x0f\n\r_total_tokens\x1a\xe1\x01\n\rTokenMetadata\x12P\n\x11input_token_count\x18\x01 \x01(\x0b\x32\x30.weaviate.v1.GenerativeGoogleMetadata.TokenCountH\x00\x88\x01\x01\x12Q\n\x12output_token_count\x18\x02 \x01(\x0b\x32\x30.weaviate.v1.GenerativeGoogleMetadata.TokenCountH\x01\x88\x01\x01\x42\x14\n\x12_input_token_countB\x15\n\x13_output_token_count\x1ao\n\x08Metadata\x12P\n\x0etoken_metadata\x18\x01 \x01(\x0b\x32\x33.weaviate.v1.GenerativeGoogleMetadata.TokenMetadataH\x00\x88\x01\x01\x42\x11\n\x0f_token_metadata\x1a\xbd\x01\n\rUsageMetadata\x12\x1f\n\x12prompt_token_count\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12#\n\x16\x63\x61ndidates_token_count\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x1e\n\x11total_token_count\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x15\n\x13_prompt_token_countB\x19\n\x17_candidates_token_countB\x14\n\x12_total_token_countB\x0b\n\t_metadataB\x11\n\x0f_usage_metadata\"\x87\x02\n\x1cGenerativeDatabricksMetadata\x12\x43\n\x05usage\x18\x01 \x01(\x0b\x32/.weaviate.v1.GenerativeDatabricksMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\x87\x02\n\x1cGenerativeFriendliAIMetadata\x12\x43\n\x05usage\x18\x01 \x01(\x0b\x32/.weaviate.v1.GenerativeFriendliAIMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\xff\x01\n\x18GenerativeNvidiaMetadata\x12?\n\x05usage\x18\x01 \x01(\x0b\x32+.weaviate.v1.GenerativeNvidiaMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\xf9\x01\n\x15GenerativeXAIMetadata\x12<\n\x05usage\x18\x01 \x01(\x0b\x32(.weaviate.v1.GenerativeXAIMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\x8f\x06\n\x12GenerativeMetadata\x12=\n\tanthropic\x18\x01 \x01(\x0b\x32(.weaviate.v1.GenerativeAnthropicMetadataH\x00\x12;\n\x08\x61nyscale\x18\x02 \x01(\x0b\x32\'.weaviate.v1.GenerativeAnyscaleMetadataH\x00\x12\x31\n\x03\x61ws\x18\x03 \x01(\x0b\x32\".weaviate.v1.GenerativeAWSMetadataH\x00\x12\x37\n\x06\x63ohere\x18\x04 \x01(\x0b\x32%.weaviate.v1.GenerativeCohereMetadataH\x00\x12\x35\n\x05\x64ummy\x18\x05 \x01(\x0b\x32$.weaviate.v1.GenerativeDummyMetadataH\x00\x12\x39\n\x07mistral\x18\x06 \x01(\x0b\x32&.weaviate.v1.GenerativeMistralMetadataH\x00\x12\x37\n\x06ollama\x18\x07 \x01(\x0b\x32%.weaviate.v1.GenerativeOllamaMetadataH\x00\x12\x37\n\x06openai\x18\x08 \x01(\x0b\x32%.weaviate.v1.GenerativeOpenAIMetadataH\x00\x12\x37\n\x06google\x18\t \x01(\x0b\x32%.weaviate.v1.GenerativeGoogleMetadataH\x00\x12?\n\ndatabricks\x18\n \x01(\x0b\x32).weaviate.v1.GenerativeDatabricksMetadataH\x00\x12?\n\nfriendliai\x18\x0b \x01(\x0b\x32).weaviate.v1.GenerativeFriendliAIMetadataH\x00\x12\x37\n\x06nvidia\x18\x0c \x01(\x0b\x32%.weaviate.v1.GenerativeNvidiaMetadataH\x00\x12\x31\n\x03xai\x18\r \x01(\x0b\x32\".weaviate.v1.GenerativeXAIMetadataH\x00\x42\x06\n\x04kind\"\xa2\x01\n\x0fGenerativeReply\x12\x0e\n\x06result\x18\x01 \x01(\t\x12\x30\n\x05\x64\x65\x62ug\x18\x02 \x01(\x0b\x32\x1c.weaviate.v1.GenerativeDebugH\x00\x88\x01\x01\x12\x36\n\x08metadata\x18\x03 \x01(\x0b\x32\x1f.weaviate.v1.GenerativeMetadataH\x01\x88\x01\x01\x42\x08\n\x06_debugB\x0b\n\t_metadata\"@\n\x10GenerativeResult\x12,\n\x06values\x18\x01 \x03(\x0b\x32\x1c.weaviate.v1.GenerativeReply\";\n\x0fGenerativeDebug\x12\x18\n\x0b\x66ull_prompt\x18\x01 \x01(\tH\x00\x88\x01\x01\x42\x0e\n\x0c_full_promptBt\n#io.weaviate.client.grpc.protocol.v1B\x17WeaviateProtoGenerativeZ4github.com/weaviate/weaviate/grpc/generated;protocolb\x06proto3') +DESCRIPTOR = _descriptor_pool.Default().AddSerializedFile(b'\n\x13v1/generative.proto\x12\x0bweaviate.v1\x1a\rv1/base.proto\"\xdd\x03\n\x10GenerativeSearch\x12\"\n\x16single_response_prompt\x18\x01 \x01(\tB\x02\x18\x01\x12!\n\x15grouped_response_task\x18\x02 \x01(\tB\x02\x18\x01\x12\x1e\n\x12grouped_properties\x18\x03 \x03(\tB\x02\x18\x01\x12\x34\n\x06single\x18\x04 \x01(\x0b\x32$.weaviate.v1.GenerativeSearch.Single\x12\x36\n\x07grouped\x18\x05 \x01(\x0b\x32%.weaviate.v1.GenerativeSearch.Grouped\x1aY\n\x06Single\x12\x0e\n\x06prompt\x18\x01 \x01(\t\x12\r\n\x05\x64\x65\x62ug\x18\x02 \x01(\x08\x12\x30\n\x07queries\x18\x03 \x03(\x0b\x32\x1f.weaviate.v1.GenerativeProvider\x1a\x98\x01\n\x07Grouped\x12\x0c\n\x04task\x18\x01 \x01(\t\x12/\n\nproperties\x18\x02 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x00\x88\x01\x01\x12\x30\n\x07queries\x18\x03 \x03(\x0b\x32\x1f.weaviate.v1.GenerativeProvider\x12\r\n\x05\x64\x65\x62ug\x18\x04 \x01(\x08\x42\r\n\x0b_properties\"\xfd\x05\n\x12GenerativeProvider\x12\x17\n\x0freturn_metadata\x18\x01 \x01(\x08\x12\x35\n\tanthropic\x18\x02 \x01(\x0b\x32 .weaviate.v1.GenerativeAnthropicH\x00\x12\x33\n\x08\x61nyscale\x18\x03 \x01(\x0b\x32\x1f.weaviate.v1.GenerativeAnyscaleH\x00\x12)\n\x03\x61ws\x18\x04 \x01(\x0b\x32\x1a.weaviate.v1.GenerativeAWSH\x00\x12/\n\x06\x63ohere\x18\x05 \x01(\x0b\x32\x1d.weaviate.v1.GenerativeCohereH\x00\x12-\n\x05\x64ummy\x18\x06 \x01(\x0b\x32\x1c.weaviate.v1.GenerativeDummyH\x00\x12\x31\n\x07mistral\x18\x07 \x01(\x0b\x32\x1e.weaviate.v1.GenerativeMistralH\x00\x12/\n\x06ollama\x18\x08 \x01(\x0b\x32\x1d.weaviate.v1.GenerativeOllamaH\x00\x12/\n\x06openai\x18\t \x01(\x0b\x32\x1d.weaviate.v1.GenerativeOpenAIH\x00\x12/\n\x06google\x18\n \x01(\x0b\x32\x1d.weaviate.v1.GenerativeGoogleH\x00\x12\x37\n\ndatabricks\x18\x0b \x01(\x0b\x32!.weaviate.v1.GenerativeDatabricksH\x00\x12\x37\n\nfriendliai\x18\x0c \x01(\x0b\x32!.weaviate.v1.GenerativeFriendliAIH\x00\x12/\n\x06nvidia\x18\r \x01(\x0b\x32\x1d.weaviate.v1.GenerativeNvidiaH\x00\x12)\n\x03xai\x18\x0e \x01(\x0b\x32\x1a.weaviate.v1.GenerativeXAIH\x00\x12;\n\x0c\x63ontextualai\x18\x0f \x01(\x0b\x32#.weaviate.v1.GenerativeContextualAIH\x00\x42\x06\n\x04kind\"\xb1\x03\n\x13GenerativeAnthropic\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x18\n\x0btemperature\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x12\n\x05top_k\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x12\n\x05top_p\x18\x06 \x01(\x01H\x05\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x07 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x06\x88\x01\x01\x12+\n\x06images\x18\x08 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x35\n\x10image_properties\x18\t \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x08\x88\x01\x01\x42\x0b\n\t_base_urlB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_kB\x08\n\x06_top_pB\x11\n\x0f_stop_sequencesB\t\n\x07_imagesB\x13\n\x11_image_properties\"\x80\x01\n\x12GenerativeAnyscale\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\x0e\n\x0c_temperature\"\x8d\x04\n\rGenerativeAWS\x12\x12\n\x05model\x18\x03 \x01(\tH\x00\x88\x01\x01\x12\x18\n\x0btemperature\x18\x08 \x01(\x01H\x01\x88\x01\x01\x12\x14\n\x07service\x18\t \x01(\tH\x02\x88\x01\x01\x12\x13\n\x06region\x18\n \x01(\tH\x03\x88\x01\x01\x12\x15\n\x08\x65ndpoint\x18\x0b \x01(\tH\x04\x88\x01\x01\x12\x19\n\x0ctarget_model\x18\x0c \x01(\tH\x05\x88\x01\x01\x12\x1b\n\x0etarget_variant\x18\r \x01(\tH\x06\x88\x01\x01\x12+\n\x06images\x18\x0e \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0f \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x08\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x10 \x01(\x03H\t\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x11 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\n\x88\x01\x01\x42\x08\n\x06_modelB\x0e\n\x0c_temperatureB\n\n\x08_serviceB\t\n\x07_regionB\x0b\n\t_endpointB\x0f\n\r_target_modelB\x11\n\x0f_target_variantB\t\n\x07_imagesB\x13\n\x11_image_propertiesB\r\n\x0b_max_tokensB\x11\n\x0f_stop_sequences\"\x88\x04\n\x10GenerativeCohere\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x1e\n\x11\x66requency_penalty\x18\x02 \x01(\x01H\x01\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x12\x12\n\x05model\x18\x04 \x01(\tH\x03\x88\x01\x01\x12\x0e\n\x01k\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x0e\n\x01p\x18\x06 \x01(\x01H\x05\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x07 \x01(\x01H\x06\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x08 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x18\n\x0btemperature\x18\t \x01(\x01H\x08\x88\x01\x01\x12+\n\x06images\x18\n \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\t\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0b \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\n\x88\x01\x01\x42\x0b\n\t_base_urlB\x14\n\x12_frequency_penaltyB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x04\n\x02_kB\x04\n\x02_pB\x13\n\x11_presence_penaltyB\x11\n\x0f_stop_sequencesB\x0e\n\x0c_temperatureB\t\n\x07_imagesB\x13\n\x11_image_properties\"\x11\n\x0fGenerativeDummy\"\xc5\x01\n\x11GenerativeMistral\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x18\n\x0btemperature\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x12\n\x05top_p\x18\x05 \x01(\x01H\x04\x88\x01\x01\x42\x0b\n\t_base_urlB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_p\"\x8a\x02\n\x10GenerativeOllama\x12\x19\n\x0c\x61pi_endpoint\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12+\n\x06images\x18\x04 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x03\x88\x01\x01\x12\x35\n\x10image_properties\x18\x05 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x04\x88\x01\x01\x42\x0f\n\r_api_endpointB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\t\n\x07_imagesB\x13\n\x11_image_properties\"\xe3\x08\n\x10GenerativeOpenAI\x12\x1e\n\x11\x66requency_penalty\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x0e\n\x01n\x18\x04 \x01(\x03H\x03\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x05 \x01(\x01H\x04\x88\x01\x01\x12)\n\x04stop\x18\x06 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x05\x88\x01\x01\x12\x18\n\x0btemperature\x18\x07 \x01(\x01H\x06\x88\x01\x01\x12\x12\n\x05top_p\x18\x08 \x01(\x01H\x07\x88\x01\x01\x12\x15\n\x08\x62\x61se_url\x18\t \x01(\tH\x08\x88\x01\x01\x12\x18\n\x0b\x61pi_version\x18\n \x01(\tH\t\x88\x01\x01\x12\x1a\n\rresource_name\x18\x0b \x01(\tH\n\x88\x01\x01\x12\x1a\n\rdeployment_id\x18\x0c \x01(\tH\x0b\x88\x01\x01\x12\x15\n\x08is_azure\x18\r \x01(\x08H\x0c\x88\x01\x01\x12+\n\x06images\x18\x0e \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\r\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0f \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x0e\x88\x01\x01\x12L\n\x10reasoning_effort\x18\x10 \x01(\x0e\x32-.weaviate.v1.GenerativeOpenAI.ReasoningEffortH\x0f\x88\x01\x01\x12?\n\tverbosity\x18\x11 \x01(\x0e\x32\'.weaviate.v1.GenerativeOpenAI.VerbosityH\x10\x88\x01\x01\"\xa3\x01\n\x0fReasoningEffort\x12 \n\x1cREASONING_EFFORT_UNSPECIFIED\x10\x00\x12\x1c\n\x18REASONING_EFFORT_MINIMAL\x10\x01\x12\x18\n\x14REASONING_EFFORT_LOW\x10\x02\x12\x1b\n\x17REASONING_EFFORT_MEDIUM\x10\x03\x12\x19\n\x15REASONING_EFFORT_HIGH\x10\x04\"c\n\tVerbosity\x12\x19\n\x15VERBOSITY_UNSPECIFIED\x10\x00\x12\x11\n\rVERBOSITY_LOW\x10\x01\x12\x14\n\x10VERBOSITY_MEDIUM\x10\x02\x12\x12\n\x0eVERBOSITY_HIGH\x10\x03\x42\x14\n\x12_frequency_penaltyB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x04\n\x02_nB\x13\n\x11_presence_penaltyB\x07\n\x05_stopB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\x0b\n\t_base_urlB\x0e\n\x0c_api_versionB\x10\n\x0e_resource_nameB\x10\n\x0e_deployment_idB\x0b\n\t_is_azureB\t\n\x07_imagesB\x13\n\x11_image_propertiesB\x13\n\x11_reasoning_effortB\x0c\n\n_verbosity\"\x92\x05\n\x10GenerativeGoogle\x12\x1e\n\x11\x66requency_penalty\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x18\n\x0btemperature\x18\x05 \x01(\x01H\x04\x88\x01\x01\x12\x12\n\x05top_k\x18\x06 \x01(\x03H\x05\x88\x01\x01\x12\x12\n\x05top_p\x18\x07 \x01(\x01H\x06\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x08 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x19\n\x0c\x61pi_endpoint\x18\t \x01(\tH\x08\x88\x01\x01\x12\x17\n\nproject_id\x18\n \x01(\tH\t\x88\x01\x01\x12\x18\n\x0b\x65ndpoint_id\x18\x0b \x01(\tH\n\x88\x01\x01\x12\x13\n\x06region\x18\x0c \x01(\tH\x0b\x88\x01\x01\x12+\n\x06images\x18\r \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x0c\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0e \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\r\x88\x01\x01\x42\x14\n\x12_frequency_penaltyB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x13\n\x11_presence_penaltyB\x0e\n\x0c_temperatureB\x08\n\x06_top_kB\x08\n\x06_top_pB\x11\n\x0f_stop_sequencesB\x0f\n\r_api_endpointB\r\n\x0b_project_idB\x0e\n\x0c_endpoint_idB\t\n\x07_regionB\t\n\x07_imagesB\x13\n\x11_image_properties\"\xd0\x03\n\x14GenerativeDatabricks\x12\x15\n\x08\x65ndpoint\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x1e\n\x11\x66requency_penalty\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x16\n\tlog_probs\x18\x04 \x01(\x08H\x03\x88\x01\x01\x12\x1a\n\rtop_log_probs\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x06 \x01(\x03H\x05\x88\x01\x01\x12\x0e\n\x01n\x18\x07 \x01(\x03H\x06\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x08 \x01(\x01H\x07\x88\x01\x01\x12)\n\x04stop\x18\t \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x08\x88\x01\x01\x12\x18\n\x0btemperature\x18\n \x01(\x01H\t\x88\x01\x01\x12\x12\n\x05top_p\x18\x0b \x01(\x01H\n\x88\x01\x01\x42\x0b\n\t_endpointB\x08\n\x06_modelB\x14\n\x12_frequency_penaltyB\x0c\n\n_log_probsB\x10\n\x0e_top_log_probsB\r\n\x0b_max_tokensB\x04\n\x02_nB\x13\n\x11_presence_penaltyB\x07\n\x05_stopB\x0e\n\x0c_temperatureB\x08\n\x06_top_p\"\xde\x01\n\x14GenerativeFriendliAI\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x12\x18\n\x0btemperature\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x0e\n\x01n\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x12\n\x05top_p\x18\x06 \x01(\x01H\x05\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\r\n\x0b_max_tokensB\x0e\n\x0c_temperatureB\x04\n\x02_nB\x08\n\x06_top_p\"\xc4\x01\n\x10GenerativeNvidia\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x12\n\x05top_p\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x05 \x01(\x03H\x04\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\r\n\x0b_max_tokens\"\xc5\x02\n\rGenerativeXAI\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x12\n\x05top_p\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12+\n\x06images\x18\x06 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x05\x88\x01\x01\x12\x35\n\x10image_properties\x18\x07 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x06\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\r\n\x0b_max_tokensB\t\n\x07_imagesB\x13\n\x11_image_properties\"\xce\x02\n\x16GenerativeContextualAI\x12\x12\n\x05model\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x18\n\x0btemperature\x18\x02 \x01(\x01H\x01\x88\x01\x01\x12\x12\n\x05top_p\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x1b\n\x0emax_new_tokens\x18\x04 \x01(\x03H\x03\x88\x01\x01\x12\x1a\n\rsystem_prompt\x18\x05 \x01(\tH\x04\x88\x01\x01\x12\x1d\n\x10\x61void_commentary\x18\x06 \x01(\x08H\x05\x88\x01\x01\x12.\n\tknowledge\x18\x07 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x06\x88\x01\x01\x42\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\x11\n\x0f_max_new_tokensB\x10\n\x0e_system_promptB\x13\n\x11_avoid_commentaryB\x0c\n\n_knowledge\"\x92\x01\n\x1bGenerativeAnthropicMetadata\x12=\n\x05usage\x18\x01 \x01(\x0b\x32..weaviate.v1.GenerativeAnthropicMetadata.Usage\x1a\x34\n\x05Usage\x12\x14\n\x0cinput_tokens\x18\x01 \x01(\x03\x12\x15\n\routput_tokens\x18\x02 \x01(\x03\"\x1c\n\x1aGenerativeAnyscaleMetadata\"\x17\n\x15GenerativeAWSMetadata\"\x9c\x06\n\x18GenerativeCohereMetadata\x12J\n\x0b\x61pi_version\x18\x01 \x01(\x0b\x32\x30.weaviate.v1.GenerativeCohereMetadata.ApiVersionH\x00\x88\x01\x01\x12L\n\x0c\x62illed_units\x18\x02 \x01(\x0b\x32\x31.weaviate.v1.GenerativeCohereMetadata.BilledUnitsH\x01\x88\x01\x01\x12\x41\n\x06tokens\x18\x03 \x01(\x0b\x32,.weaviate.v1.GenerativeCohereMetadata.TokensH\x02\x88\x01\x01\x12-\n\x08warnings\x18\x04 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x03\x88\x01\x01\x1a\x8e\x01\n\nApiVersion\x12\x14\n\x07version\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x1a\n\ris_deprecated\x18\x02 \x01(\x08H\x01\x88\x01\x01\x12\x1c\n\x0fis_experimental\x18\x03 \x01(\x08H\x02\x88\x01\x01\x42\n\n\x08_versionB\x10\n\x0e_is_deprecatedB\x12\n\x10_is_experimental\x1a\xc5\x01\n\x0b\x42illedUnits\x12\x19\n\x0cinput_tokens\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x1a\n\routput_tokens\x18\x02 \x01(\x01H\x01\x88\x01\x01\x12\x19\n\x0csearch_units\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x1c\n\x0f\x63lassifications\x18\x04 \x01(\x01H\x03\x88\x01\x01\x42\x0f\n\r_input_tokensB\x10\n\x0e_output_tokensB\x0f\n\r_search_unitsB\x12\n\x10_classifications\x1a\x62\n\x06Tokens\x12\x19\n\x0cinput_tokens\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x1a\n\routput_tokens\x18\x02 \x01(\x01H\x01\x88\x01\x01\x42\x0f\n\r_input_tokensB\x10\n\x0e_output_tokensB\x0e\n\x0c_api_versionB\x0f\n\r_billed_unitsB\t\n\x07_tokensB\x0b\n\t_warnings\"\x19\n\x17GenerativeDummyMetadata\"\x81\x02\n\x19GenerativeMistralMetadata\x12@\n\x05usage\x18\x01 \x01(\x0b\x32,.weaviate.v1.GenerativeMistralMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\x1a\n\x18GenerativeOllamaMetadata\"\xff\x01\n\x18GenerativeOpenAIMetadata\x12?\n\x05usage\x18\x01 \x01(\x0b\x32+.weaviate.v1.GenerativeOpenAIMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\xe8\x06\n\x18GenerativeGoogleMetadata\x12\x45\n\x08metadata\x18\x01 \x01(\x0b\x32..weaviate.v1.GenerativeGoogleMetadata.MetadataH\x00\x88\x01\x01\x12P\n\x0eusage_metadata\x18\x02 \x01(\x0b\x32\x33.weaviate.v1.GenerativeGoogleMetadata.UsageMetadataH\x01\x88\x01\x01\x1a~\n\nTokenCount\x12&\n\x19total_billable_characters\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x42\x1c\n\x1a_total_billable_charactersB\x0f\n\r_total_tokens\x1a\xe1\x01\n\rTokenMetadata\x12P\n\x11input_token_count\x18\x01 \x01(\x0b\x32\x30.weaviate.v1.GenerativeGoogleMetadata.TokenCountH\x00\x88\x01\x01\x12Q\n\x12output_token_count\x18\x02 \x01(\x0b\x32\x30.weaviate.v1.GenerativeGoogleMetadata.TokenCountH\x01\x88\x01\x01\x42\x14\n\x12_input_token_countB\x15\n\x13_output_token_count\x1ao\n\x08Metadata\x12P\n\x0etoken_metadata\x18\x01 \x01(\x0b\x32\x33.weaviate.v1.GenerativeGoogleMetadata.TokenMetadataH\x00\x88\x01\x01\x42\x11\n\x0f_token_metadata\x1a\xbd\x01\n\rUsageMetadata\x12\x1f\n\x12prompt_token_count\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12#\n\x16\x63\x61ndidates_token_count\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x1e\n\x11total_token_count\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x15\n\x13_prompt_token_countB\x19\n\x17_candidates_token_countB\x14\n\x12_total_token_countB\x0b\n\t_metadataB\x11\n\x0f_usage_metadata\"\x87\x02\n\x1cGenerativeDatabricksMetadata\x12\x43\n\x05usage\x18\x01 \x01(\x0b\x32/.weaviate.v1.GenerativeDatabricksMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\x87\x02\n\x1cGenerativeFriendliAIMetadata\x12\x43\n\x05usage\x18\x01 \x01(\x0b\x32/.weaviate.v1.GenerativeFriendliAIMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\xff\x01\n\x18GenerativeNvidiaMetadata\x12?\n\x05usage\x18\x01 \x01(\x0b\x32+.weaviate.v1.GenerativeNvidiaMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\xf9\x01\n\x15GenerativeXAIMetadata\x12<\n\x05usage\x18\x01 \x01(\x0b\x32(.weaviate.v1.GenerativeXAIMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\x8f\x06\n\x12GenerativeMetadata\x12=\n\tanthropic\x18\x01 \x01(\x0b\x32(.weaviate.v1.GenerativeAnthropicMetadataH\x00\x12;\n\x08\x61nyscale\x18\x02 \x01(\x0b\x32\'.weaviate.v1.GenerativeAnyscaleMetadataH\x00\x12\x31\n\x03\x61ws\x18\x03 \x01(\x0b\x32\".weaviate.v1.GenerativeAWSMetadataH\x00\x12\x37\n\x06\x63ohere\x18\x04 \x01(\x0b\x32%.weaviate.v1.GenerativeCohereMetadataH\x00\x12\x35\n\x05\x64ummy\x18\x05 \x01(\x0b\x32$.weaviate.v1.GenerativeDummyMetadataH\x00\x12\x39\n\x07mistral\x18\x06 \x01(\x0b\x32&.weaviate.v1.GenerativeMistralMetadataH\x00\x12\x37\n\x06ollama\x18\x07 \x01(\x0b\x32%.weaviate.v1.GenerativeOllamaMetadataH\x00\x12\x37\n\x06openai\x18\x08 \x01(\x0b\x32%.weaviate.v1.GenerativeOpenAIMetadataH\x00\x12\x37\n\x06google\x18\t \x01(\x0b\x32%.weaviate.v1.GenerativeGoogleMetadataH\x00\x12?\n\ndatabricks\x18\n \x01(\x0b\x32).weaviate.v1.GenerativeDatabricksMetadataH\x00\x12?\n\nfriendliai\x18\x0b \x01(\x0b\x32).weaviate.v1.GenerativeFriendliAIMetadataH\x00\x12\x37\n\x06nvidia\x18\x0c \x01(\x0b\x32%.weaviate.v1.GenerativeNvidiaMetadataH\x00\x12\x31\n\x03xai\x18\r \x01(\x0b\x32\".weaviate.v1.GenerativeXAIMetadataH\x00\x42\x06\n\x04kind\"\xa2\x01\n\x0fGenerativeReply\x12\x0e\n\x06result\x18\x01 \x01(\t\x12\x30\n\x05\x64\x65\x62ug\x18\x02 \x01(\x0b\x32\x1c.weaviate.v1.GenerativeDebugH\x00\x88\x01\x01\x12\x36\n\x08metadata\x18\x03 \x01(\x0b\x32\x1f.weaviate.v1.GenerativeMetadataH\x01\x88\x01\x01\x42\x08\n\x06_debugB\x0b\n\t_metadata\"@\n\x10GenerativeResult\x12,\n\x06values\x18\x01 \x03(\x0b\x32\x1c.weaviate.v1.GenerativeReply\";\n\x0fGenerativeDebug\x12\x18\n\x0b\x66ull_prompt\x18\x01 \x01(\tH\x00\x88\x01\x01\x42\x0e\n\x0c_full_promptBt\n#io.weaviate.client.grpc.protocol.v1B\x17WeaviateProtoGenerativeZ4github.com/weaviate/weaviate/grpc/generated;protocolb\x06proto3') _globals = globals() _builder.BuildMessageAndEnumDescriptors(DESCRIPTOR, _globals) @@ -41,93 +41,93 @@ _globals['_GENERATIVEANYSCALE']._serialized_start=1736 _globals['_GENERATIVEANYSCALE']._serialized_end=1864 _globals['_GENERATIVEAWS']._serialized_start=1867 - _globals['_GENERATIVEAWS']._serialized_end=2320 - _globals['_GENERATIVECOHERE']._serialized_start=2323 - _globals['_GENERATIVECOHERE']._serialized_end=2843 - _globals['_GENERATIVEDUMMY']._serialized_start=2845 - _globals['_GENERATIVEDUMMY']._serialized_end=2862 - _globals['_GENERATIVEMISTRAL']._serialized_start=2865 - _globals['_GENERATIVEMISTRAL']._serialized_end=3062 - _globals['_GENERATIVEOLLAMA']._serialized_start=3065 - _globals['_GENERATIVEOLLAMA']._serialized_end=3331 - _globals['_GENERATIVEOPENAI']._serialized_start=3334 - _globals['_GENERATIVEOPENAI']._serialized_end=4457 - _globals['_GENERATIVEOPENAI_REASONINGEFFORT']._serialized_start=3939 - _globals['_GENERATIVEOPENAI_REASONINGEFFORT']._serialized_end=4102 - _globals['_GENERATIVEOPENAI_VERBOSITY']._serialized_start=4104 - _globals['_GENERATIVEOPENAI_VERBOSITY']._serialized_end=4203 - _globals['_GENERATIVEGOOGLE']._serialized_start=4460 - _globals['_GENERATIVEGOOGLE']._serialized_end=5118 - _globals['_GENERATIVEDATABRICKS']._serialized_start=5121 - _globals['_GENERATIVEDATABRICKS']._serialized_end=5585 - _globals['_GENERATIVEFRIENDLIAI']._serialized_start=5588 - _globals['_GENERATIVEFRIENDLIAI']._serialized_end=5810 - _globals['_GENERATIVENVIDIA']._serialized_start=5813 - _globals['_GENERATIVENVIDIA']._serialized_end=6009 - _globals['_GENERATIVEXAI']._serialized_start=6012 - _globals['_GENERATIVEXAI']._serialized_end=6337 - _globals['_GENERATIVECONTEXTUALAI']._serialized_start=6340 - _globals['_GENERATIVECONTEXTUALAI']._serialized_end=6674 - _globals['_GENERATIVEANTHROPICMETADATA']._serialized_start=6677 - _globals['_GENERATIVEANTHROPICMETADATA']._serialized_end=6823 - _globals['_GENERATIVEANTHROPICMETADATA_USAGE']._serialized_start=6771 - _globals['_GENERATIVEANTHROPICMETADATA_USAGE']._serialized_end=6823 - _globals['_GENERATIVEANYSCALEMETADATA']._serialized_start=6825 - _globals['_GENERATIVEANYSCALEMETADATA']._serialized_end=6853 - _globals['_GENERATIVEAWSMETADATA']._serialized_start=6855 - _globals['_GENERATIVEAWSMETADATA']._serialized_end=6878 - _globals['_GENERATIVECOHEREMETADATA']._serialized_start=6881 - _globals['_GENERATIVECOHEREMETADATA']._serialized_end=7677 - _globals['_GENERATIVECOHEREMETADATA_APIVERSION']._serialized_start=7178 - _globals['_GENERATIVECOHEREMETADATA_APIVERSION']._serialized_end=7320 - _globals['_GENERATIVECOHEREMETADATA_BILLEDUNITS']._serialized_start=7323 - _globals['_GENERATIVECOHEREMETADATA_BILLEDUNITS']._serialized_end=7520 - _globals['_GENERATIVECOHEREMETADATA_TOKENS']._serialized_start=7522 - _globals['_GENERATIVECOHEREMETADATA_TOKENS']._serialized_end=7620 - _globals['_GENERATIVEDUMMYMETADATA']._serialized_start=7679 - _globals['_GENERATIVEDUMMYMETADATA']._serialized_end=7704 - _globals['_GENERATIVEMISTRALMETADATA']._serialized_start=7707 - _globals['_GENERATIVEMISTRALMETADATA']._serialized_end=7964 - _globals['_GENERATIVEMISTRALMETADATA_USAGE']._serialized_start=7803 - _globals['_GENERATIVEMISTRALMETADATA_USAGE']._serialized_end=7954 - _globals['_GENERATIVEOLLAMAMETADATA']._serialized_start=7966 - _globals['_GENERATIVEOLLAMAMETADATA']._serialized_end=7992 - _globals['_GENERATIVEOPENAIMETADATA']._serialized_start=7995 - _globals['_GENERATIVEOPENAIMETADATA']._serialized_end=8250 - _globals['_GENERATIVEOPENAIMETADATA_USAGE']._serialized_start=7803 - _globals['_GENERATIVEOPENAIMETADATA_USAGE']._serialized_end=7954 - _globals['_GENERATIVEGOOGLEMETADATA']._serialized_start=8253 - _globals['_GENERATIVEGOOGLEMETADATA']._serialized_end=9125 - _globals['_GENERATIVEGOOGLEMETADATA_TOKENCOUNT']._serialized_start=8434 - _globals['_GENERATIVEGOOGLEMETADATA_TOKENCOUNT']._serialized_end=8560 - _globals['_GENERATIVEGOOGLEMETADATA_TOKENMETADATA']._serialized_start=8563 - _globals['_GENERATIVEGOOGLEMETADATA_TOKENMETADATA']._serialized_end=8788 - _globals['_GENERATIVEGOOGLEMETADATA_METADATA']._serialized_start=8790 - _globals['_GENERATIVEGOOGLEMETADATA_METADATA']._serialized_end=8901 - _globals['_GENERATIVEGOOGLEMETADATA_USAGEMETADATA']._serialized_start=8904 - _globals['_GENERATIVEGOOGLEMETADATA_USAGEMETADATA']._serialized_end=9093 - _globals['_GENERATIVEDATABRICKSMETADATA']._serialized_start=9128 - _globals['_GENERATIVEDATABRICKSMETADATA']._serialized_end=9391 - _globals['_GENERATIVEDATABRICKSMETADATA_USAGE']._serialized_start=7803 - _globals['_GENERATIVEDATABRICKSMETADATA_USAGE']._serialized_end=7954 - _globals['_GENERATIVEFRIENDLIAIMETADATA']._serialized_start=9394 - _globals['_GENERATIVEFRIENDLIAIMETADATA']._serialized_end=9657 - _globals['_GENERATIVEFRIENDLIAIMETADATA_USAGE']._serialized_start=7803 - _globals['_GENERATIVEFRIENDLIAIMETADATA_USAGE']._serialized_end=7954 - _globals['_GENERATIVENVIDIAMETADATA']._serialized_start=9660 - _globals['_GENERATIVENVIDIAMETADATA']._serialized_end=9915 - _globals['_GENERATIVENVIDIAMETADATA_USAGE']._serialized_start=7803 - _globals['_GENERATIVENVIDIAMETADATA_USAGE']._serialized_end=7954 - _globals['_GENERATIVEXAIMETADATA']._serialized_start=9918 - _globals['_GENERATIVEXAIMETADATA']._serialized_end=10167 - _globals['_GENERATIVEXAIMETADATA_USAGE']._serialized_start=7803 - _globals['_GENERATIVEXAIMETADATA_USAGE']._serialized_end=7954 - _globals['_GENERATIVEMETADATA']._serialized_start=10170 - _globals['_GENERATIVEMETADATA']._serialized_end=10953 - _globals['_GENERATIVEREPLY']._serialized_start=10956 - _globals['_GENERATIVEREPLY']._serialized_end=11118 - _globals['_GENERATIVERESULT']._serialized_start=11120 - _globals['_GENERATIVERESULT']._serialized_end=11184 - _globals['_GENERATIVEDEBUG']._serialized_start=11186 - _globals['_GENERATIVEDEBUG']._serialized_end=11245 + _globals['_GENERATIVEAWS']._serialized_end=2392 + _globals['_GENERATIVECOHERE']._serialized_start=2395 + _globals['_GENERATIVECOHERE']._serialized_end=2915 + _globals['_GENERATIVEDUMMY']._serialized_start=2917 + _globals['_GENERATIVEDUMMY']._serialized_end=2934 + _globals['_GENERATIVEMISTRAL']._serialized_start=2937 + _globals['_GENERATIVEMISTRAL']._serialized_end=3134 + _globals['_GENERATIVEOLLAMA']._serialized_start=3137 + _globals['_GENERATIVEOLLAMA']._serialized_end=3403 + _globals['_GENERATIVEOPENAI']._serialized_start=3406 + _globals['_GENERATIVEOPENAI']._serialized_end=4529 + _globals['_GENERATIVEOPENAI_REASONINGEFFORT']._serialized_start=4011 + _globals['_GENERATIVEOPENAI_REASONINGEFFORT']._serialized_end=4174 + _globals['_GENERATIVEOPENAI_VERBOSITY']._serialized_start=4176 + _globals['_GENERATIVEOPENAI_VERBOSITY']._serialized_end=4275 + _globals['_GENERATIVEGOOGLE']._serialized_start=4532 + _globals['_GENERATIVEGOOGLE']._serialized_end=5190 + _globals['_GENERATIVEDATABRICKS']._serialized_start=5193 + _globals['_GENERATIVEDATABRICKS']._serialized_end=5657 + _globals['_GENERATIVEFRIENDLIAI']._serialized_start=5660 + _globals['_GENERATIVEFRIENDLIAI']._serialized_end=5882 + _globals['_GENERATIVENVIDIA']._serialized_start=5885 + _globals['_GENERATIVENVIDIA']._serialized_end=6081 + _globals['_GENERATIVEXAI']._serialized_start=6084 + _globals['_GENERATIVEXAI']._serialized_end=6409 + _globals['_GENERATIVECONTEXTUALAI']._serialized_start=6412 + _globals['_GENERATIVECONTEXTUALAI']._serialized_end=6746 + _globals['_GENERATIVEANTHROPICMETADATA']._serialized_start=6749 + _globals['_GENERATIVEANTHROPICMETADATA']._serialized_end=6895 + _globals['_GENERATIVEANTHROPICMETADATA_USAGE']._serialized_start=6843 + _globals['_GENERATIVEANTHROPICMETADATA_USAGE']._serialized_end=6895 + _globals['_GENERATIVEANYSCALEMETADATA']._serialized_start=6897 + _globals['_GENERATIVEANYSCALEMETADATA']._serialized_end=6925 + _globals['_GENERATIVEAWSMETADATA']._serialized_start=6927 + _globals['_GENERATIVEAWSMETADATA']._serialized_end=6950 + _globals['_GENERATIVECOHEREMETADATA']._serialized_start=6953 + _globals['_GENERATIVECOHEREMETADATA']._serialized_end=7749 + _globals['_GENERATIVECOHEREMETADATA_APIVERSION']._serialized_start=7250 + _globals['_GENERATIVECOHEREMETADATA_APIVERSION']._serialized_end=7392 + _globals['_GENERATIVECOHEREMETADATA_BILLEDUNITS']._serialized_start=7395 + _globals['_GENERATIVECOHEREMETADATA_BILLEDUNITS']._serialized_end=7592 + _globals['_GENERATIVECOHEREMETADATA_TOKENS']._serialized_start=7594 + _globals['_GENERATIVECOHEREMETADATA_TOKENS']._serialized_end=7692 + _globals['_GENERATIVEDUMMYMETADATA']._serialized_start=7751 + _globals['_GENERATIVEDUMMYMETADATA']._serialized_end=7776 + _globals['_GENERATIVEMISTRALMETADATA']._serialized_start=7779 + _globals['_GENERATIVEMISTRALMETADATA']._serialized_end=8036 + _globals['_GENERATIVEMISTRALMETADATA_USAGE']._serialized_start=7875 + _globals['_GENERATIVEMISTRALMETADATA_USAGE']._serialized_end=8026 + _globals['_GENERATIVEOLLAMAMETADATA']._serialized_start=8038 + _globals['_GENERATIVEOLLAMAMETADATA']._serialized_end=8064 + _globals['_GENERATIVEOPENAIMETADATA']._serialized_start=8067 + _globals['_GENERATIVEOPENAIMETADATA']._serialized_end=8322 + _globals['_GENERATIVEOPENAIMETADATA_USAGE']._serialized_start=7875 + _globals['_GENERATIVEOPENAIMETADATA_USAGE']._serialized_end=8026 + _globals['_GENERATIVEGOOGLEMETADATA']._serialized_start=8325 + _globals['_GENERATIVEGOOGLEMETADATA']._serialized_end=9197 + _globals['_GENERATIVEGOOGLEMETADATA_TOKENCOUNT']._serialized_start=8506 + _globals['_GENERATIVEGOOGLEMETADATA_TOKENCOUNT']._serialized_end=8632 + _globals['_GENERATIVEGOOGLEMETADATA_TOKENMETADATA']._serialized_start=8635 + _globals['_GENERATIVEGOOGLEMETADATA_TOKENMETADATA']._serialized_end=8860 + _globals['_GENERATIVEGOOGLEMETADATA_METADATA']._serialized_start=8862 + _globals['_GENERATIVEGOOGLEMETADATA_METADATA']._serialized_end=8973 + _globals['_GENERATIVEGOOGLEMETADATA_USAGEMETADATA']._serialized_start=8976 + _globals['_GENERATIVEGOOGLEMETADATA_USAGEMETADATA']._serialized_end=9165 + _globals['_GENERATIVEDATABRICKSMETADATA']._serialized_start=9200 + _globals['_GENERATIVEDATABRICKSMETADATA']._serialized_end=9463 + _globals['_GENERATIVEDATABRICKSMETADATA_USAGE']._serialized_start=7875 + _globals['_GENERATIVEDATABRICKSMETADATA_USAGE']._serialized_end=8026 + _globals['_GENERATIVEFRIENDLIAIMETADATA']._serialized_start=9466 + _globals['_GENERATIVEFRIENDLIAIMETADATA']._serialized_end=9729 + _globals['_GENERATIVEFRIENDLIAIMETADATA_USAGE']._serialized_start=7875 + _globals['_GENERATIVEFRIENDLIAIMETADATA_USAGE']._serialized_end=8026 + _globals['_GENERATIVENVIDIAMETADATA']._serialized_start=9732 + _globals['_GENERATIVENVIDIAMETADATA']._serialized_end=9987 + _globals['_GENERATIVENVIDIAMETADATA_USAGE']._serialized_start=7875 + _globals['_GENERATIVENVIDIAMETADATA_USAGE']._serialized_end=8026 + _globals['_GENERATIVEXAIMETADATA']._serialized_start=9990 + _globals['_GENERATIVEXAIMETADATA']._serialized_end=10239 + _globals['_GENERATIVEXAIMETADATA_USAGE']._serialized_start=7875 + _globals['_GENERATIVEXAIMETADATA_USAGE']._serialized_end=8026 + _globals['_GENERATIVEMETADATA']._serialized_start=10242 + _globals['_GENERATIVEMETADATA']._serialized_end=11025 + _globals['_GENERATIVEREPLY']._serialized_start=11028 + _globals['_GENERATIVEREPLY']._serialized_end=11190 + _globals['_GENERATIVERESULT']._serialized_start=11192 + _globals['_GENERATIVERESULT']._serialized_end=11256 + _globals['_GENERATIVEDEBUG']._serialized_start=11258 + _globals['_GENERATIVEDEBUG']._serialized_end=11317 # @@protoc_insertion_point(module_scope) diff --git a/weaviate/proto/v1/v4216/v1/generative_pb2.pyi b/weaviate/proto/v1/v4216/v1/generative_pb2.pyi index 0aec8d653..0cbad0694 100644 --- a/weaviate/proto/v1/v4216/v1/generative_pb2.pyi +++ b/weaviate/proto/v1/v4216/v1/generative_pb2.pyi @@ -108,7 +108,7 @@ class GenerativeAnyscale(_message.Message): def __init__(self, base_url: _Optional[str] = ..., model: _Optional[str] = ..., temperature: _Optional[float] = ...) -> None: ... class GenerativeAWS(_message.Message): - __slots__ = ["model", "temperature", "service", "region", "endpoint", "target_model", "target_variant", "images", "image_properties", "max_tokens"] + __slots__ = ["model", "temperature", "service", "region", "endpoint", "target_model", "target_variant", "images", "image_properties", "max_tokens", "stop_sequences"] MODEL_FIELD_NUMBER: _ClassVar[int] TEMPERATURE_FIELD_NUMBER: _ClassVar[int] SERVICE_FIELD_NUMBER: _ClassVar[int] @@ -119,6 +119,7 @@ class GenerativeAWS(_message.Message): IMAGES_FIELD_NUMBER: _ClassVar[int] IMAGE_PROPERTIES_FIELD_NUMBER: _ClassVar[int] MAX_TOKENS_FIELD_NUMBER: _ClassVar[int] + STOP_SEQUENCES_FIELD_NUMBER: _ClassVar[int] model: str temperature: float service: str @@ -129,7 +130,8 @@ class GenerativeAWS(_message.Message): images: _base_pb2.TextArray image_properties: _base_pb2.TextArray max_tokens: int - def __init__(self, model: _Optional[str] = ..., temperature: _Optional[float] = ..., service: _Optional[str] = ..., region: _Optional[str] = ..., endpoint: _Optional[str] = ..., target_model: _Optional[str] = ..., target_variant: _Optional[str] = ..., images: _Optional[_Union[_base_pb2.TextArray, _Mapping]] = ..., image_properties: _Optional[_Union[_base_pb2.TextArray, _Mapping]] = ..., max_tokens: _Optional[int] = ...) -> None: ... + stop_sequences: _base_pb2.TextArray + def __init__(self, model: _Optional[str] = ..., temperature: _Optional[float] = ..., service: _Optional[str] = ..., region: _Optional[str] = ..., endpoint: _Optional[str] = ..., target_model: _Optional[str] = ..., target_variant: _Optional[str] = ..., images: _Optional[_Union[_base_pb2.TextArray, _Mapping]] = ..., image_properties: _Optional[_Union[_base_pb2.TextArray, _Mapping]] = ..., max_tokens: _Optional[int] = ..., stop_sequences: _Optional[_Union[_base_pb2.TextArray, _Mapping]] = ...) -> None: ... class GenerativeCohere(_message.Message): __slots__ = ["base_url", "frequency_penalty", "max_tokens", "model", "k", "p", "presence_penalty", "stop_sequences", "temperature", "images", "image_properties"] diff --git a/weaviate/proto/v1/v5261/v1/batch_pb2.py b/weaviate/proto/v1/v5261/v1/batch_pb2.py index 86b722431..de1c4807a 100644 --- a/weaviate/proto/v1/v5261/v1/batch_pb2.py +++ b/weaviate/proto/v1/v5261/v1/batch_pb2.py @@ -16,7 +16,7 @@ from weaviate.proto.v1.v5261.v1 import base_pb2 as v1_dot_base__pb2 -DESCRIPTOR = _descriptor_pool.Default().AddSerializedFile(b'\n\x0ev1/batch.proto\x12\x0bweaviate.v1\x1a\x1cgoogle/protobuf/struct.proto\x1a\rv1/base.proto\"\x95\x01\n\x13\x42\x61tchObjectsRequest\x12)\n\x07objects\x18\x01 \x03(\x0b\x32\x18.weaviate.v1.BatchObject\x12=\n\x11\x63onsistency_level\x18\x02 \x01(\x0e\x32\x1d.weaviate.v1.ConsistencyLevelH\x00\x88\x01\x01\x42\x14\n\x12_consistency_level\"\x9e\x01\n\x16\x42\x61tchReferencesRequest\x12/\n\nreferences\x18\x01 \x03(\x0b\x32\x1b.weaviate.v1.BatchReference\x12=\n\x11\x63onsistency_level\x18\x02 \x01(\x0e\x32\x1d.weaviate.v1.ConsistencyLevelH\x00\x88\x01\x01\x42\x14\n\x12_consistency_level\"\xa6\x04\n\x12\x42\x61tchStreamRequest\x12\x36\n\x05start\x18\x01 \x01(\x0b\x32%.weaviate.v1.BatchStreamRequest.StartH\x00\x12\x34\n\x04\x64\x61ta\x18\x02 \x01(\x0b\x32$.weaviate.v1.BatchStreamRequest.DataH\x00\x12\x34\n\x04stop\x18\x03 \x01(\x0b\x32$.weaviate.v1.BatchStreamRequest.StopH\x00\x1a\\\n\x05Start\x12=\n\x11\x63onsistency_level\x18\x01 \x01(\x0e\x32\x1d.weaviate.v1.ConsistencyLevelH\x00\x88\x01\x01\x42\x14\n\x12_consistency_level\x1a\x06\n\x04Stop\x1a\xfa\x01\n\x04\x44\x61ta\x12=\n\x07objects\x18\x01 \x01(\x0b\x32,.weaviate.v1.BatchStreamRequest.Data.Objects\x12\x43\n\nreferences\x18\x02 \x01(\x0b\x32/.weaviate.v1.BatchStreamRequest.Data.References\x1a\x33\n\x07Objects\x12(\n\x06values\x18\x01 \x03(\x0b\x32\x18.weaviate.v1.BatchObject\x1a\x39\n\nReferences\x12+\n\x06values\x18\x01 \x03(\x0b\x32\x1b.weaviate.v1.BatchReferenceB\t\n\x07message\"\x98\x05\n\x10\x42\x61tchStreamReply\x12\x38\n\x07results\x18\x01 \x01(\x0b\x32%.weaviate.v1.BatchStreamReply.ResultsH\x00\x12\x43\n\rshutting_down\x18\x02 \x01(\x0b\x32*.weaviate.v1.BatchStreamReply.ShuttingDownH\x00\x12:\n\x08shutdown\x18\x03 \x01(\x0b\x32&.weaviate.v1.BatchStreamReply.ShutdownH\x00\x12\x38\n\x07started\x18\x04 \x01(\x0b\x32%.weaviate.v1.BatchStreamReply.StartedH\x00\x12\x38\n\x07\x62\x61\x63koff\x18\x05 \x01(\x0b\x32%.weaviate.v1.BatchStreamReply.BackoffH\x00\x1a\t\n\x07Started\x1a\x0e\n\x0cShuttingDown\x1a\n\n\x08Shutdown\x1a\x1d\n\x07\x42\x61\x63koff\x12\x12\n\nbatch_size\x18\x01 \x01(\x05\x1a\x83\x02\n\x07Results\x12;\n\x06\x65rrors\x18\x01 \x03(\x0b\x32+.weaviate.v1.BatchStreamReply.Results.Error\x12@\n\tsuccesses\x18\x02 \x03(\x0b\x32-.weaviate.v1.BatchStreamReply.Results.Success\x1a\x42\n\x05\x45rror\x12\r\n\x05\x65rror\x18\x01 \x01(\t\x12\x0e\n\x04uuid\x18\x02 \x01(\tH\x00\x12\x10\n\x06\x62\x65\x61\x63on\x18\x03 \x01(\tH\x00\x42\x08\n\x06\x64\x65tail\x1a\x35\n\x07Success\x12\x0e\n\x04uuid\x18\x02 \x01(\tH\x00\x12\x10\n\x06\x62\x65\x61\x63on\x18\x03 \x01(\tH\x00\x42\x08\n\x06\x64\x65tailB\t\n\x07message\"\xde\x07\n\x0b\x42\x61tchObject\x12\x0c\n\x04uuid\x18\x01 \x01(\t\x12\x12\n\x06vector\x18\x02 \x03(\x02\x42\x02\x18\x01\x12\x37\n\nproperties\x18\x03 \x01(\x0b\x32#.weaviate.v1.BatchObject.Properties\x12\x12\n\ncollection\x18\x04 \x01(\t\x12\x0e\n\x06tenant\x18\x05 \x01(\t\x12\x14\n\x0cvector_bytes\x18\x06 \x01(\x0c\x12%\n\x07vectors\x18\x17 \x03(\x0b\x32\x14.weaviate.v1.Vectors\x1a\x84\x05\n\nProperties\x12\x33\n\x12non_ref_properties\x18\x01 \x01(\x0b\x32\x17.google.protobuf.Struct\x12N\n\x17single_target_ref_props\x18\x02 \x03(\x0b\x32-.weaviate.v1.BatchObject.SingleTargetRefProps\x12L\n\x16multi_target_ref_props\x18\x03 \x03(\x0b\x32,.weaviate.v1.BatchObject.MultiTargetRefProps\x12\x43\n\x17number_array_properties\x18\x04 \x03(\x0b\x32\".weaviate.v1.NumberArrayProperties\x12=\n\x14int_array_properties\x18\x05 \x03(\x0b\x32\x1f.weaviate.v1.IntArrayProperties\x12?\n\x15text_array_properties\x18\x06 \x03(\x0b\x32 .weaviate.v1.TextArrayProperties\x12\x45\n\x18\x62oolean_array_properties\x18\x07 \x03(\x0b\x32#.weaviate.v1.BooleanArrayProperties\x12\x38\n\x11object_properties\x18\x08 \x03(\x0b\x32\x1d.weaviate.v1.ObjectProperties\x12\x43\n\x17object_array_properties\x18\t \x03(\x0b\x32\".weaviate.v1.ObjectArrayProperties\x12\x18\n\x10\x65mpty_list_props\x18\n \x03(\t\x1a\x38\n\x14SingleTargetRefProps\x12\r\n\x05uuids\x18\x01 \x03(\t\x12\x11\n\tprop_name\x18\x02 \x01(\t\x1aR\n\x13MultiTargetRefProps\x12\r\n\x05uuids\x18\x01 \x03(\t\x12\x11\n\tprop_name\x18\x02 \x01(\t\x12\x19\n\x11target_collection\x18\x03 \x01(\t\"\x99\x01\n\x0e\x42\x61tchReference\x12\x0c\n\x04name\x18\x01 \x01(\t\x12\x17\n\x0f\x66rom_collection\x18\x02 \x01(\t\x12\x11\n\tfrom_uuid\x18\x03 \x01(\t\x12\x1a\n\rto_collection\x18\x04 \x01(\tH\x00\x88\x01\x01\x12\x0f\n\x07to_uuid\x18\x05 \x01(\t\x12\x0e\n\x06tenant\x18\x06 \x01(\tB\x10\n\x0e_to_collection\"\x88\x01\n\x11\x42\x61tchObjectsReply\x12\x0c\n\x04took\x18\x01 \x01(\x02\x12\x39\n\x06\x65rrors\x18\x02 \x03(\x0b\x32).weaviate.v1.BatchObjectsReply.BatchError\x1a*\n\nBatchError\x12\r\n\x05index\x18\x01 \x01(\x05\x12\r\n\x05\x65rror\x18\x02 \x01(\t\"\x8e\x01\n\x14\x42\x61tchReferencesReply\x12\x0c\n\x04took\x18\x01 \x01(\x02\x12<\n\x06\x65rrors\x18\x02 \x03(\x0b\x32,.weaviate.v1.BatchReferencesReply.BatchError\x1a*\n\nBatchError\x12\r\n\x05index\x18\x01 \x01(\x05\x12\r\n\x05\x65rror\x18\x02 \x01(\tBo\n#io.weaviate.client.grpc.protocol.v1B\x12WeaviateProtoBatchZ4github.com/weaviate/weaviate/grpc/generated;protocolb\x06proto3') +DESCRIPTOR = _descriptor_pool.Default().AddSerializedFile(b'\n\x0ev1/batch.proto\x12\x0bweaviate.v1\x1a\x1cgoogle/protobuf/struct.proto\x1a\rv1/base.proto\"\x95\x01\n\x13\x42\x61tchObjectsRequest\x12)\n\x07objects\x18\x01 \x03(\x0b\x32\x18.weaviate.v1.BatchObject\x12=\n\x11\x63onsistency_level\x18\x02 \x01(\x0e\x32\x1d.weaviate.v1.ConsistencyLevelH\x00\x88\x01\x01\x42\x14\n\x12_consistency_level\"\x9e\x01\n\x16\x42\x61tchReferencesRequest\x12/\n\nreferences\x18\x01 \x03(\x0b\x32\x1b.weaviate.v1.BatchReference\x12=\n\x11\x63onsistency_level\x18\x02 \x01(\x0e\x32\x1d.weaviate.v1.ConsistencyLevelH\x00\x88\x01\x01\x42\x14\n\x12_consistency_level\"\xa6\x04\n\x12\x42\x61tchStreamRequest\x12\x36\n\x05start\x18\x01 \x01(\x0b\x32%.weaviate.v1.BatchStreamRequest.StartH\x00\x12\x34\n\x04\x64\x61ta\x18\x02 \x01(\x0b\x32$.weaviate.v1.BatchStreamRequest.DataH\x00\x12\x34\n\x04stop\x18\x03 \x01(\x0b\x32$.weaviate.v1.BatchStreamRequest.StopH\x00\x1a\\\n\x05Start\x12=\n\x11\x63onsistency_level\x18\x01 \x01(\x0e\x32\x1d.weaviate.v1.ConsistencyLevelH\x00\x88\x01\x01\x42\x14\n\x12_consistency_level\x1a\x06\n\x04Stop\x1a\xfa\x01\n\x04\x44\x61ta\x12=\n\x07objects\x18\x01 \x01(\x0b\x32,.weaviate.v1.BatchStreamRequest.Data.Objects\x12\x43\n\nreferences\x18\x02 \x01(\x0b\x32/.weaviate.v1.BatchStreamRequest.Data.References\x1a\x33\n\x07Objects\x12(\n\x06values\x18\x01 \x03(\x0b\x32\x18.weaviate.v1.BatchObject\x1a\x39\n\nReferences\x12+\n\x06values\x18\x01 \x03(\x0b\x32\x1b.weaviate.v1.BatchReferenceB\t\n\x07message\"\xe7\x06\n\x10\x42\x61tchStreamReply\x12\x38\n\x07results\x18\x01 \x01(\x0b\x32%.weaviate.v1.BatchStreamReply.ResultsH\x00\x12\x43\n\rshutting_down\x18\x02 \x01(\x0b\x32*.weaviate.v1.BatchStreamReply.ShuttingDownH\x00\x12:\n\x08shutdown\x18\x03 \x01(\x0b\x32&.weaviate.v1.BatchStreamReply.ShutdownH\x00\x12\x38\n\x07started\x18\x04 \x01(\x0b\x32%.weaviate.v1.BatchStreamReply.StartedH\x00\x12\x38\n\x07\x62\x61\x63koff\x18\x05 \x01(\x0b\x32%.weaviate.v1.BatchStreamReply.BackoffH\x00\x12\x32\n\x04\x61\x63ks\x18\x06 \x01(\x0b\x32\".weaviate.v1.BatchStreamReply.AcksH\x00\x12\x42\n\rout_of_memory\x18\x07 \x01(\x0b\x32).weaviate.v1.BatchStreamReply.OutOfMemoryH\x00\x1a\t\n\x07Started\x1a\x0e\n\x0cShuttingDown\x1a\n\n\x08Shutdown\x1a-\n\x0bOutOfMemory\x12\r\n\x05uuids\x18\x01 \x03(\t\x12\x0f\n\x07\x62\x65\x61\x63ons\x18\x02 \x03(\t\x1a\x1d\n\x07\x42\x61\x63koff\x12\x12\n\nbatch_size\x18\x01 \x01(\x05\x1a&\n\x04\x41\x63ks\x12\r\n\x05uuids\x18\x01 \x03(\t\x12\x0f\n\x07\x62\x65\x61\x63ons\x18\x02 \x03(\t\x1a\x83\x02\n\x07Results\x12;\n\x06\x65rrors\x18\x01 \x03(\x0b\x32+.weaviate.v1.BatchStreamReply.Results.Error\x12@\n\tsuccesses\x18\x02 \x03(\x0b\x32-.weaviate.v1.BatchStreamReply.Results.Success\x1a\x42\n\x05\x45rror\x12\r\n\x05\x65rror\x18\x01 \x01(\t\x12\x0e\n\x04uuid\x18\x02 \x01(\tH\x00\x12\x10\n\x06\x62\x65\x61\x63on\x18\x03 \x01(\tH\x00\x42\x08\n\x06\x64\x65tail\x1a\x35\n\x07Success\x12\x0e\n\x04uuid\x18\x02 \x01(\tH\x00\x12\x10\n\x06\x62\x65\x61\x63on\x18\x03 \x01(\tH\x00\x42\x08\n\x06\x64\x65tailB\t\n\x07message\"\xde\x07\n\x0b\x42\x61tchObject\x12\x0c\n\x04uuid\x18\x01 \x01(\t\x12\x12\n\x06vector\x18\x02 \x03(\x02\x42\x02\x18\x01\x12\x37\n\nproperties\x18\x03 \x01(\x0b\x32#.weaviate.v1.BatchObject.Properties\x12\x12\n\ncollection\x18\x04 \x01(\t\x12\x0e\n\x06tenant\x18\x05 \x01(\t\x12\x14\n\x0cvector_bytes\x18\x06 \x01(\x0c\x12%\n\x07vectors\x18\x17 \x03(\x0b\x32\x14.weaviate.v1.Vectors\x1a\x84\x05\n\nProperties\x12\x33\n\x12non_ref_properties\x18\x01 \x01(\x0b\x32\x17.google.protobuf.Struct\x12N\n\x17single_target_ref_props\x18\x02 \x03(\x0b\x32-.weaviate.v1.BatchObject.SingleTargetRefProps\x12L\n\x16multi_target_ref_props\x18\x03 \x03(\x0b\x32,.weaviate.v1.BatchObject.MultiTargetRefProps\x12\x43\n\x17number_array_properties\x18\x04 \x03(\x0b\x32\".weaviate.v1.NumberArrayProperties\x12=\n\x14int_array_properties\x18\x05 \x03(\x0b\x32\x1f.weaviate.v1.IntArrayProperties\x12?\n\x15text_array_properties\x18\x06 \x03(\x0b\x32 .weaviate.v1.TextArrayProperties\x12\x45\n\x18\x62oolean_array_properties\x18\x07 \x03(\x0b\x32#.weaviate.v1.BooleanArrayProperties\x12\x38\n\x11object_properties\x18\x08 \x03(\x0b\x32\x1d.weaviate.v1.ObjectProperties\x12\x43\n\x17object_array_properties\x18\t \x03(\x0b\x32\".weaviate.v1.ObjectArrayProperties\x12\x18\n\x10\x65mpty_list_props\x18\n \x03(\t\x1a\x38\n\x14SingleTargetRefProps\x12\r\n\x05uuids\x18\x01 \x03(\t\x12\x11\n\tprop_name\x18\x02 \x01(\t\x1aR\n\x13MultiTargetRefProps\x12\r\n\x05uuids\x18\x01 \x03(\t\x12\x11\n\tprop_name\x18\x02 \x01(\t\x12\x19\n\x11target_collection\x18\x03 \x01(\t\"\x99\x01\n\x0e\x42\x61tchReference\x12\x0c\n\x04name\x18\x01 \x01(\t\x12\x17\n\x0f\x66rom_collection\x18\x02 \x01(\t\x12\x11\n\tfrom_uuid\x18\x03 \x01(\t\x12\x1a\n\rto_collection\x18\x04 \x01(\tH\x00\x88\x01\x01\x12\x0f\n\x07to_uuid\x18\x05 \x01(\t\x12\x0e\n\x06tenant\x18\x06 \x01(\tB\x10\n\x0e_to_collection\"\x88\x01\n\x11\x42\x61tchObjectsReply\x12\x0c\n\x04took\x18\x01 \x01(\x02\x12\x39\n\x06\x65rrors\x18\x02 \x03(\x0b\x32).weaviate.v1.BatchObjectsReply.BatchError\x1a*\n\nBatchError\x12\r\n\x05index\x18\x01 \x01(\x05\x12\r\n\x05\x65rror\x18\x02 \x01(\t\"\x8e\x01\n\x14\x42\x61tchReferencesReply\x12\x0c\n\x04took\x18\x01 \x01(\x02\x12<\n\x06\x65rrors\x18\x02 \x03(\x0b\x32,.weaviate.v1.BatchReferencesReply.BatchError\x1a*\n\nBatchError\x12\r\n\x05index\x18\x01 \x01(\x05\x12\r\n\x05\x65rror\x18\x02 \x01(\tBo\n#io.weaviate.client.grpc.protocol.v1B\x12WeaviateProtoBatchZ4github.com/weaviate/weaviate/grpc/generated;protocolb\x06proto3') _globals = globals() _builder.BuildMessageAndEnumDescriptors(DESCRIPTOR, _globals) @@ -43,37 +43,41 @@ _globals['_BATCHSTREAMREQUEST_DATA_REFERENCES']._serialized_start=872 _globals['_BATCHSTREAMREQUEST_DATA_REFERENCES']._serialized_end=929 _globals['_BATCHSTREAMREPLY']._serialized_start=943 - _globals['_BATCHSTREAMREPLY']._serialized_end=1607 - _globals['_BATCHSTREAMREPLY_STARTED']._serialized_start=1266 - _globals['_BATCHSTREAMREPLY_STARTED']._serialized_end=1275 - _globals['_BATCHSTREAMREPLY_SHUTTINGDOWN']._serialized_start=1277 - _globals['_BATCHSTREAMREPLY_SHUTTINGDOWN']._serialized_end=1291 - _globals['_BATCHSTREAMREPLY_SHUTDOWN']._serialized_start=1293 - _globals['_BATCHSTREAMREPLY_SHUTDOWN']._serialized_end=1303 - _globals['_BATCHSTREAMREPLY_BACKOFF']._serialized_start=1305 - _globals['_BATCHSTREAMREPLY_BACKOFF']._serialized_end=1334 - _globals['_BATCHSTREAMREPLY_RESULTS']._serialized_start=1337 - _globals['_BATCHSTREAMREPLY_RESULTS']._serialized_end=1596 - _globals['_BATCHSTREAMREPLY_RESULTS_ERROR']._serialized_start=1475 - _globals['_BATCHSTREAMREPLY_RESULTS_ERROR']._serialized_end=1541 - _globals['_BATCHSTREAMREPLY_RESULTS_SUCCESS']._serialized_start=1543 - _globals['_BATCHSTREAMREPLY_RESULTS_SUCCESS']._serialized_end=1596 - _globals['_BATCHOBJECT']._serialized_start=1610 - _globals['_BATCHOBJECT']._serialized_end=2600 - _globals['_BATCHOBJECT_PROPERTIES']._serialized_start=1814 - _globals['_BATCHOBJECT_PROPERTIES']._serialized_end=2458 - _globals['_BATCHOBJECT_SINGLETARGETREFPROPS']._serialized_start=2460 - _globals['_BATCHOBJECT_SINGLETARGETREFPROPS']._serialized_end=2516 - _globals['_BATCHOBJECT_MULTITARGETREFPROPS']._serialized_start=2518 - _globals['_BATCHOBJECT_MULTITARGETREFPROPS']._serialized_end=2600 - _globals['_BATCHREFERENCE']._serialized_start=2603 - _globals['_BATCHREFERENCE']._serialized_end=2756 - _globals['_BATCHOBJECTSREPLY']._serialized_start=2759 - _globals['_BATCHOBJECTSREPLY']._serialized_end=2895 - _globals['_BATCHOBJECTSREPLY_BATCHERROR']._serialized_start=2853 - _globals['_BATCHOBJECTSREPLY_BATCHERROR']._serialized_end=2895 - _globals['_BATCHREFERENCESREPLY']._serialized_start=2898 - _globals['_BATCHREFERENCESREPLY']._serialized_end=3040 - _globals['_BATCHREFERENCESREPLY_BATCHERROR']._serialized_start=2853 - _globals['_BATCHREFERENCESREPLY_BATCHERROR']._serialized_end=2895 + _globals['_BATCHSTREAMREPLY']._serialized_end=1814 + _globals['_BATCHSTREAMREPLY_STARTED']._serialized_start=1386 + _globals['_BATCHSTREAMREPLY_STARTED']._serialized_end=1395 + _globals['_BATCHSTREAMREPLY_SHUTTINGDOWN']._serialized_start=1397 + _globals['_BATCHSTREAMREPLY_SHUTTINGDOWN']._serialized_end=1411 + _globals['_BATCHSTREAMREPLY_SHUTDOWN']._serialized_start=1413 + _globals['_BATCHSTREAMREPLY_SHUTDOWN']._serialized_end=1423 + _globals['_BATCHSTREAMREPLY_OUTOFMEMORY']._serialized_start=1425 + _globals['_BATCHSTREAMREPLY_OUTOFMEMORY']._serialized_end=1470 + _globals['_BATCHSTREAMREPLY_BACKOFF']._serialized_start=1472 + _globals['_BATCHSTREAMREPLY_BACKOFF']._serialized_end=1501 + _globals['_BATCHSTREAMREPLY_ACKS']._serialized_start=1503 + _globals['_BATCHSTREAMREPLY_ACKS']._serialized_end=1541 + _globals['_BATCHSTREAMREPLY_RESULTS']._serialized_start=1544 + _globals['_BATCHSTREAMREPLY_RESULTS']._serialized_end=1803 + _globals['_BATCHSTREAMREPLY_RESULTS_ERROR']._serialized_start=1682 + _globals['_BATCHSTREAMREPLY_RESULTS_ERROR']._serialized_end=1748 + _globals['_BATCHSTREAMREPLY_RESULTS_SUCCESS']._serialized_start=1750 + _globals['_BATCHSTREAMREPLY_RESULTS_SUCCESS']._serialized_end=1803 + _globals['_BATCHOBJECT']._serialized_start=1817 + _globals['_BATCHOBJECT']._serialized_end=2807 + _globals['_BATCHOBJECT_PROPERTIES']._serialized_start=2021 + _globals['_BATCHOBJECT_PROPERTIES']._serialized_end=2665 + _globals['_BATCHOBJECT_SINGLETARGETREFPROPS']._serialized_start=2667 + _globals['_BATCHOBJECT_SINGLETARGETREFPROPS']._serialized_end=2723 + _globals['_BATCHOBJECT_MULTITARGETREFPROPS']._serialized_start=2725 + _globals['_BATCHOBJECT_MULTITARGETREFPROPS']._serialized_end=2807 + _globals['_BATCHREFERENCE']._serialized_start=2810 + _globals['_BATCHREFERENCE']._serialized_end=2963 + _globals['_BATCHOBJECTSREPLY']._serialized_start=2966 + _globals['_BATCHOBJECTSREPLY']._serialized_end=3102 + _globals['_BATCHOBJECTSREPLY_BATCHERROR']._serialized_start=3060 + _globals['_BATCHOBJECTSREPLY_BATCHERROR']._serialized_end=3102 + _globals['_BATCHREFERENCESREPLY']._serialized_start=3105 + _globals['_BATCHREFERENCESREPLY']._serialized_end=3247 + _globals['_BATCHREFERENCESREPLY_BATCHERROR']._serialized_start=3060 + _globals['_BATCHREFERENCESREPLY_BATCHERROR']._serialized_end=3102 # @@protoc_insertion_point(module_scope) diff --git a/weaviate/proto/v1/v5261/v1/batch_pb2.pyi b/weaviate/proto/v1/v5261/v1/batch_pb2.pyi index d975b0157..bf476fecf 100644 --- a/weaviate/proto/v1/v5261/v1/batch_pb2.pyi +++ b/weaviate/proto/v1/v5261/v1/batch_pb2.pyi @@ -59,7 +59,7 @@ class BatchStreamRequest(_message.Message): def __init__(self, start: _Optional[_Union[BatchStreamRequest.Start, _Mapping]] = ..., data: _Optional[_Union[BatchStreamRequest.Data, _Mapping]] = ..., stop: _Optional[_Union[BatchStreamRequest.Stop, _Mapping]] = ...) -> None: ... class BatchStreamReply(_message.Message): - __slots__ = ("results", "shutting_down", "shutdown", "started", "backoff") + __slots__ = ("results", "shutting_down", "shutdown", "started", "backoff", "acks", "out_of_memory") class Started(_message.Message): __slots__ = () def __init__(self) -> None: ... @@ -69,11 +69,25 @@ class BatchStreamReply(_message.Message): class Shutdown(_message.Message): __slots__ = () def __init__(self) -> None: ... + class OutOfMemory(_message.Message): + __slots__ = ("uuids", "beacons") + UUIDS_FIELD_NUMBER: _ClassVar[int] + BEACONS_FIELD_NUMBER: _ClassVar[int] + uuids: _containers.RepeatedScalarFieldContainer[str] + beacons: _containers.RepeatedScalarFieldContainer[str] + def __init__(self, uuids: _Optional[_Iterable[str]] = ..., beacons: _Optional[_Iterable[str]] = ...) -> None: ... class Backoff(_message.Message): __slots__ = ("batch_size",) BATCH_SIZE_FIELD_NUMBER: _ClassVar[int] batch_size: int def __init__(self, batch_size: _Optional[int] = ...) -> None: ... + class Acks(_message.Message): + __slots__ = ("uuids", "beacons") + UUIDS_FIELD_NUMBER: _ClassVar[int] + BEACONS_FIELD_NUMBER: _ClassVar[int] + uuids: _containers.RepeatedScalarFieldContainer[str] + beacons: _containers.RepeatedScalarFieldContainer[str] + def __init__(self, uuids: _Optional[_Iterable[str]] = ..., beacons: _Optional[_Iterable[str]] = ...) -> None: ... class Results(_message.Message): __slots__ = ("errors", "successes") class Error(_message.Message): @@ -102,12 +116,16 @@ class BatchStreamReply(_message.Message): SHUTDOWN_FIELD_NUMBER: _ClassVar[int] STARTED_FIELD_NUMBER: _ClassVar[int] BACKOFF_FIELD_NUMBER: _ClassVar[int] + ACKS_FIELD_NUMBER: _ClassVar[int] + OUT_OF_MEMORY_FIELD_NUMBER: _ClassVar[int] results: BatchStreamReply.Results shutting_down: BatchStreamReply.ShuttingDown shutdown: BatchStreamReply.Shutdown started: BatchStreamReply.Started backoff: BatchStreamReply.Backoff - def __init__(self, results: _Optional[_Union[BatchStreamReply.Results, _Mapping]] = ..., shutting_down: _Optional[_Union[BatchStreamReply.ShuttingDown, _Mapping]] = ..., shutdown: _Optional[_Union[BatchStreamReply.Shutdown, _Mapping]] = ..., started: _Optional[_Union[BatchStreamReply.Started, _Mapping]] = ..., backoff: _Optional[_Union[BatchStreamReply.Backoff, _Mapping]] = ...) -> None: ... + acks: BatchStreamReply.Acks + out_of_memory: BatchStreamReply.OutOfMemory + def __init__(self, results: _Optional[_Union[BatchStreamReply.Results, _Mapping]] = ..., shutting_down: _Optional[_Union[BatchStreamReply.ShuttingDown, _Mapping]] = ..., shutdown: _Optional[_Union[BatchStreamReply.Shutdown, _Mapping]] = ..., started: _Optional[_Union[BatchStreamReply.Started, _Mapping]] = ..., backoff: _Optional[_Union[BatchStreamReply.Backoff, _Mapping]] = ..., acks: _Optional[_Union[BatchStreamReply.Acks, _Mapping]] = ..., out_of_memory: _Optional[_Union[BatchStreamReply.OutOfMemory, _Mapping]] = ...) -> None: ... class BatchObject(_message.Message): __slots__ = ("uuid", "vector", "properties", "collection", "tenant", "vector_bytes", "vectors") diff --git a/weaviate/proto/v1/v5261/v1/generative_pb2.py b/weaviate/proto/v1/v5261/v1/generative_pb2.py index 1b84afcd7..cf4f84a1d 100644 --- a/weaviate/proto/v1/v5261/v1/generative_pb2.py +++ b/weaviate/proto/v1/v5261/v1/generative_pb2.py @@ -15,7 +15,7 @@ from weaviate.proto.v1.v5261.v1 import base_pb2 as v1_dot_base__pb2 -DESCRIPTOR = _descriptor_pool.Default().AddSerializedFile(b'\n\x13v1/generative.proto\x12\x0bweaviate.v1\x1a\rv1/base.proto\"\xdd\x03\n\x10GenerativeSearch\x12\"\n\x16single_response_prompt\x18\x01 \x01(\tB\x02\x18\x01\x12!\n\x15grouped_response_task\x18\x02 \x01(\tB\x02\x18\x01\x12\x1e\n\x12grouped_properties\x18\x03 \x03(\tB\x02\x18\x01\x12\x34\n\x06single\x18\x04 \x01(\x0b\x32$.weaviate.v1.GenerativeSearch.Single\x12\x36\n\x07grouped\x18\x05 \x01(\x0b\x32%.weaviate.v1.GenerativeSearch.Grouped\x1aY\n\x06Single\x12\x0e\n\x06prompt\x18\x01 \x01(\t\x12\r\n\x05\x64\x65\x62ug\x18\x02 \x01(\x08\x12\x30\n\x07queries\x18\x03 \x03(\x0b\x32\x1f.weaviate.v1.GenerativeProvider\x1a\x98\x01\n\x07Grouped\x12\x0c\n\x04task\x18\x01 \x01(\t\x12/\n\nproperties\x18\x02 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x00\x88\x01\x01\x12\x30\n\x07queries\x18\x03 \x03(\x0b\x32\x1f.weaviate.v1.GenerativeProvider\x12\r\n\x05\x64\x65\x62ug\x18\x04 \x01(\x08\x42\r\n\x0b_properties\"\xfd\x05\n\x12GenerativeProvider\x12\x17\n\x0freturn_metadata\x18\x01 \x01(\x08\x12\x35\n\tanthropic\x18\x02 \x01(\x0b\x32 .weaviate.v1.GenerativeAnthropicH\x00\x12\x33\n\x08\x61nyscale\x18\x03 \x01(\x0b\x32\x1f.weaviate.v1.GenerativeAnyscaleH\x00\x12)\n\x03\x61ws\x18\x04 \x01(\x0b\x32\x1a.weaviate.v1.GenerativeAWSH\x00\x12/\n\x06\x63ohere\x18\x05 \x01(\x0b\x32\x1d.weaviate.v1.GenerativeCohereH\x00\x12-\n\x05\x64ummy\x18\x06 \x01(\x0b\x32\x1c.weaviate.v1.GenerativeDummyH\x00\x12\x31\n\x07mistral\x18\x07 \x01(\x0b\x32\x1e.weaviate.v1.GenerativeMistralH\x00\x12/\n\x06ollama\x18\x08 \x01(\x0b\x32\x1d.weaviate.v1.GenerativeOllamaH\x00\x12/\n\x06openai\x18\t \x01(\x0b\x32\x1d.weaviate.v1.GenerativeOpenAIH\x00\x12/\n\x06google\x18\n \x01(\x0b\x32\x1d.weaviate.v1.GenerativeGoogleH\x00\x12\x37\n\ndatabricks\x18\x0b \x01(\x0b\x32!.weaviate.v1.GenerativeDatabricksH\x00\x12\x37\n\nfriendliai\x18\x0c \x01(\x0b\x32!.weaviate.v1.GenerativeFriendliAIH\x00\x12/\n\x06nvidia\x18\r \x01(\x0b\x32\x1d.weaviate.v1.GenerativeNvidiaH\x00\x12)\n\x03xai\x18\x0e \x01(\x0b\x32\x1a.weaviate.v1.GenerativeXAIH\x00\x12;\n\x0c\x63ontextualai\x18\x0f \x01(\x0b\x32#.weaviate.v1.GenerativeContextualAIH\x00\x42\x06\n\x04kind\"\xb1\x03\n\x13GenerativeAnthropic\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x18\n\x0btemperature\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x12\n\x05top_k\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x12\n\x05top_p\x18\x06 \x01(\x01H\x05\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x07 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x06\x88\x01\x01\x12+\n\x06images\x18\x08 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x35\n\x10image_properties\x18\t \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x08\x88\x01\x01\x42\x0b\n\t_base_urlB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_kB\x08\n\x06_top_pB\x11\n\x0f_stop_sequencesB\t\n\x07_imagesB\x13\n\x11_image_properties\"\x80\x01\n\x12GenerativeAnyscale\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\x0e\n\x0c_temperature\"\xc5\x03\n\rGenerativeAWS\x12\x12\n\x05model\x18\x03 \x01(\tH\x00\x88\x01\x01\x12\x18\n\x0btemperature\x18\x08 \x01(\x01H\x01\x88\x01\x01\x12\x14\n\x07service\x18\t \x01(\tH\x02\x88\x01\x01\x12\x13\n\x06region\x18\n \x01(\tH\x03\x88\x01\x01\x12\x15\n\x08\x65ndpoint\x18\x0b \x01(\tH\x04\x88\x01\x01\x12\x19\n\x0ctarget_model\x18\x0c \x01(\tH\x05\x88\x01\x01\x12\x1b\n\x0etarget_variant\x18\r \x01(\tH\x06\x88\x01\x01\x12+\n\x06images\x18\x0e \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0f \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x08\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x10 \x01(\x03H\t\x88\x01\x01\x42\x08\n\x06_modelB\x0e\n\x0c_temperatureB\n\n\x08_serviceB\t\n\x07_regionB\x0b\n\t_endpointB\x0f\n\r_target_modelB\x11\n\x0f_target_variantB\t\n\x07_imagesB\x13\n\x11_image_propertiesB\r\n\x0b_max_tokens\"\x88\x04\n\x10GenerativeCohere\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x1e\n\x11\x66requency_penalty\x18\x02 \x01(\x01H\x01\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x12\x12\n\x05model\x18\x04 \x01(\tH\x03\x88\x01\x01\x12\x0e\n\x01k\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x0e\n\x01p\x18\x06 \x01(\x01H\x05\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x07 \x01(\x01H\x06\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x08 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x18\n\x0btemperature\x18\t \x01(\x01H\x08\x88\x01\x01\x12+\n\x06images\x18\n \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\t\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0b \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\n\x88\x01\x01\x42\x0b\n\t_base_urlB\x14\n\x12_frequency_penaltyB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x04\n\x02_kB\x04\n\x02_pB\x13\n\x11_presence_penaltyB\x11\n\x0f_stop_sequencesB\x0e\n\x0c_temperatureB\t\n\x07_imagesB\x13\n\x11_image_properties\"\x11\n\x0fGenerativeDummy\"\xc5\x01\n\x11GenerativeMistral\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x18\n\x0btemperature\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x12\n\x05top_p\x18\x05 \x01(\x01H\x04\x88\x01\x01\x42\x0b\n\t_base_urlB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_p\"\x8a\x02\n\x10GenerativeOllama\x12\x19\n\x0c\x61pi_endpoint\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12+\n\x06images\x18\x04 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x03\x88\x01\x01\x12\x35\n\x10image_properties\x18\x05 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x04\x88\x01\x01\x42\x0f\n\r_api_endpointB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\t\n\x07_imagesB\x13\n\x11_image_properties\"\xe3\x08\n\x10GenerativeOpenAI\x12\x1e\n\x11\x66requency_penalty\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x0e\n\x01n\x18\x04 \x01(\x03H\x03\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x05 \x01(\x01H\x04\x88\x01\x01\x12)\n\x04stop\x18\x06 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x05\x88\x01\x01\x12\x18\n\x0btemperature\x18\x07 \x01(\x01H\x06\x88\x01\x01\x12\x12\n\x05top_p\x18\x08 \x01(\x01H\x07\x88\x01\x01\x12\x15\n\x08\x62\x61se_url\x18\t \x01(\tH\x08\x88\x01\x01\x12\x18\n\x0b\x61pi_version\x18\n \x01(\tH\t\x88\x01\x01\x12\x1a\n\rresource_name\x18\x0b \x01(\tH\n\x88\x01\x01\x12\x1a\n\rdeployment_id\x18\x0c \x01(\tH\x0b\x88\x01\x01\x12\x15\n\x08is_azure\x18\r \x01(\x08H\x0c\x88\x01\x01\x12+\n\x06images\x18\x0e \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\r\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0f \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x0e\x88\x01\x01\x12L\n\x10reasoning_effort\x18\x10 \x01(\x0e\x32-.weaviate.v1.GenerativeOpenAI.ReasoningEffortH\x0f\x88\x01\x01\x12?\n\tverbosity\x18\x11 \x01(\x0e\x32\'.weaviate.v1.GenerativeOpenAI.VerbosityH\x10\x88\x01\x01\"\xa3\x01\n\x0fReasoningEffort\x12 \n\x1cREASONING_EFFORT_UNSPECIFIED\x10\x00\x12\x1c\n\x18REASONING_EFFORT_MINIMAL\x10\x01\x12\x18\n\x14REASONING_EFFORT_LOW\x10\x02\x12\x1b\n\x17REASONING_EFFORT_MEDIUM\x10\x03\x12\x19\n\x15REASONING_EFFORT_HIGH\x10\x04\"c\n\tVerbosity\x12\x19\n\x15VERBOSITY_UNSPECIFIED\x10\x00\x12\x11\n\rVERBOSITY_LOW\x10\x01\x12\x14\n\x10VERBOSITY_MEDIUM\x10\x02\x12\x12\n\x0eVERBOSITY_HIGH\x10\x03\x42\x14\n\x12_frequency_penaltyB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x04\n\x02_nB\x13\n\x11_presence_penaltyB\x07\n\x05_stopB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\x0b\n\t_base_urlB\x0e\n\x0c_api_versionB\x10\n\x0e_resource_nameB\x10\n\x0e_deployment_idB\x0b\n\t_is_azureB\t\n\x07_imagesB\x13\n\x11_image_propertiesB\x13\n\x11_reasoning_effortB\x0c\n\n_verbosity\"\x92\x05\n\x10GenerativeGoogle\x12\x1e\n\x11\x66requency_penalty\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x18\n\x0btemperature\x18\x05 \x01(\x01H\x04\x88\x01\x01\x12\x12\n\x05top_k\x18\x06 \x01(\x03H\x05\x88\x01\x01\x12\x12\n\x05top_p\x18\x07 \x01(\x01H\x06\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x08 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x19\n\x0c\x61pi_endpoint\x18\t \x01(\tH\x08\x88\x01\x01\x12\x17\n\nproject_id\x18\n \x01(\tH\t\x88\x01\x01\x12\x18\n\x0b\x65ndpoint_id\x18\x0b \x01(\tH\n\x88\x01\x01\x12\x13\n\x06region\x18\x0c \x01(\tH\x0b\x88\x01\x01\x12+\n\x06images\x18\r \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x0c\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0e \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\r\x88\x01\x01\x42\x14\n\x12_frequency_penaltyB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x13\n\x11_presence_penaltyB\x0e\n\x0c_temperatureB\x08\n\x06_top_kB\x08\n\x06_top_pB\x11\n\x0f_stop_sequencesB\x0f\n\r_api_endpointB\r\n\x0b_project_idB\x0e\n\x0c_endpoint_idB\t\n\x07_regionB\t\n\x07_imagesB\x13\n\x11_image_properties\"\xd0\x03\n\x14GenerativeDatabricks\x12\x15\n\x08\x65ndpoint\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x1e\n\x11\x66requency_penalty\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x16\n\tlog_probs\x18\x04 \x01(\x08H\x03\x88\x01\x01\x12\x1a\n\rtop_log_probs\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x06 \x01(\x03H\x05\x88\x01\x01\x12\x0e\n\x01n\x18\x07 \x01(\x03H\x06\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x08 \x01(\x01H\x07\x88\x01\x01\x12)\n\x04stop\x18\t \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x08\x88\x01\x01\x12\x18\n\x0btemperature\x18\n \x01(\x01H\t\x88\x01\x01\x12\x12\n\x05top_p\x18\x0b \x01(\x01H\n\x88\x01\x01\x42\x0b\n\t_endpointB\x08\n\x06_modelB\x14\n\x12_frequency_penaltyB\x0c\n\n_log_probsB\x10\n\x0e_top_log_probsB\r\n\x0b_max_tokensB\x04\n\x02_nB\x13\n\x11_presence_penaltyB\x07\n\x05_stopB\x0e\n\x0c_temperatureB\x08\n\x06_top_p\"\xde\x01\n\x14GenerativeFriendliAI\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x12\x18\n\x0btemperature\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x0e\n\x01n\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x12\n\x05top_p\x18\x06 \x01(\x01H\x05\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\r\n\x0b_max_tokensB\x0e\n\x0c_temperatureB\x04\n\x02_nB\x08\n\x06_top_p\"\xc4\x01\n\x10GenerativeNvidia\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x12\n\x05top_p\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x05 \x01(\x03H\x04\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\r\n\x0b_max_tokens\"\xc5\x02\n\rGenerativeXAI\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x12\n\x05top_p\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12+\n\x06images\x18\x06 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x05\x88\x01\x01\x12\x35\n\x10image_properties\x18\x07 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x06\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\r\n\x0b_max_tokensB\t\n\x07_imagesB\x13\n\x11_image_properties\"\xce\x02\n\x16GenerativeContextualAI\x12\x12\n\x05model\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x18\n\x0btemperature\x18\x02 \x01(\x01H\x01\x88\x01\x01\x12\x12\n\x05top_p\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x1b\n\x0emax_new_tokens\x18\x04 \x01(\x03H\x03\x88\x01\x01\x12\x1a\n\rsystem_prompt\x18\x05 \x01(\tH\x04\x88\x01\x01\x12\x1d\n\x10\x61void_commentary\x18\x06 \x01(\x08H\x05\x88\x01\x01\x12.\n\tknowledge\x18\x07 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x06\x88\x01\x01\x42\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\x11\n\x0f_max_new_tokensB\x10\n\x0e_system_promptB\x13\n\x11_avoid_commentaryB\x0c\n\n_knowledge\"\x92\x01\n\x1bGenerativeAnthropicMetadata\x12=\n\x05usage\x18\x01 \x01(\x0b\x32..weaviate.v1.GenerativeAnthropicMetadata.Usage\x1a\x34\n\x05Usage\x12\x14\n\x0cinput_tokens\x18\x01 \x01(\x03\x12\x15\n\routput_tokens\x18\x02 \x01(\x03\"\x1c\n\x1aGenerativeAnyscaleMetadata\"\x17\n\x15GenerativeAWSMetadata\"\x9c\x06\n\x18GenerativeCohereMetadata\x12J\n\x0b\x61pi_version\x18\x01 \x01(\x0b\x32\x30.weaviate.v1.GenerativeCohereMetadata.ApiVersionH\x00\x88\x01\x01\x12L\n\x0c\x62illed_units\x18\x02 \x01(\x0b\x32\x31.weaviate.v1.GenerativeCohereMetadata.BilledUnitsH\x01\x88\x01\x01\x12\x41\n\x06tokens\x18\x03 \x01(\x0b\x32,.weaviate.v1.GenerativeCohereMetadata.TokensH\x02\x88\x01\x01\x12-\n\x08warnings\x18\x04 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x03\x88\x01\x01\x1a\x8e\x01\n\nApiVersion\x12\x14\n\x07version\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x1a\n\ris_deprecated\x18\x02 \x01(\x08H\x01\x88\x01\x01\x12\x1c\n\x0fis_experimental\x18\x03 \x01(\x08H\x02\x88\x01\x01\x42\n\n\x08_versionB\x10\n\x0e_is_deprecatedB\x12\n\x10_is_experimental\x1a\xc5\x01\n\x0b\x42illedUnits\x12\x19\n\x0cinput_tokens\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x1a\n\routput_tokens\x18\x02 \x01(\x01H\x01\x88\x01\x01\x12\x19\n\x0csearch_units\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x1c\n\x0f\x63lassifications\x18\x04 \x01(\x01H\x03\x88\x01\x01\x42\x0f\n\r_input_tokensB\x10\n\x0e_output_tokensB\x0f\n\r_search_unitsB\x12\n\x10_classifications\x1a\x62\n\x06Tokens\x12\x19\n\x0cinput_tokens\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x1a\n\routput_tokens\x18\x02 \x01(\x01H\x01\x88\x01\x01\x42\x0f\n\r_input_tokensB\x10\n\x0e_output_tokensB\x0e\n\x0c_api_versionB\x0f\n\r_billed_unitsB\t\n\x07_tokensB\x0b\n\t_warnings\"\x19\n\x17GenerativeDummyMetadata\"\x81\x02\n\x19GenerativeMistralMetadata\x12@\n\x05usage\x18\x01 \x01(\x0b\x32,.weaviate.v1.GenerativeMistralMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\x1a\n\x18GenerativeOllamaMetadata\"\xff\x01\n\x18GenerativeOpenAIMetadata\x12?\n\x05usage\x18\x01 \x01(\x0b\x32+.weaviate.v1.GenerativeOpenAIMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\xe8\x06\n\x18GenerativeGoogleMetadata\x12\x45\n\x08metadata\x18\x01 \x01(\x0b\x32..weaviate.v1.GenerativeGoogleMetadata.MetadataH\x00\x88\x01\x01\x12P\n\x0eusage_metadata\x18\x02 \x01(\x0b\x32\x33.weaviate.v1.GenerativeGoogleMetadata.UsageMetadataH\x01\x88\x01\x01\x1a~\n\nTokenCount\x12&\n\x19total_billable_characters\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x42\x1c\n\x1a_total_billable_charactersB\x0f\n\r_total_tokens\x1a\xe1\x01\n\rTokenMetadata\x12P\n\x11input_token_count\x18\x01 \x01(\x0b\x32\x30.weaviate.v1.GenerativeGoogleMetadata.TokenCountH\x00\x88\x01\x01\x12Q\n\x12output_token_count\x18\x02 \x01(\x0b\x32\x30.weaviate.v1.GenerativeGoogleMetadata.TokenCountH\x01\x88\x01\x01\x42\x14\n\x12_input_token_countB\x15\n\x13_output_token_count\x1ao\n\x08Metadata\x12P\n\x0etoken_metadata\x18\x01 \x01(\x0b\x32\x33.weaviate.v1.GenerativeGoogleMetadata.TokenMetadataH\x00\x88\x01\x01\x42\x11\n\x0f_token_metadata\x1a\xbd\x01\n\rUsageMetadata\x12\x1f\n\x12prompt_token_count\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12#\n\x16\x63\x61ndidates_token_count\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x1e\n\x11total_token_count\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x15\n\x13_prompt_token_countB\x19\n\x17_candidates_token_countB\x14\n\x12_total_token_countB\x0b\n\t_metadataB\x11\n\x0f_usage_metadata\"\x87\x02\n\x1cGenerativeDatabricksMetadata\x12\x43\n\x05usage\x18\x01 \x01(\x0b\x32/.weaviate.v1.GenerativeDatabricksMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\x87\x02\n\x1cGenerativeFriendliAIMetadata\x12\x43\n\x05usage\x18\x01 \x01(\x0b\x32/.weaviate.v1.GenerativeFriendliAIMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\xff\x01\n\x18GenerativeNvidiaMetadata\x12?\n\x05usage\x18\x01 \x01(\x0b\x32+.weaviate.v1.GenerativeNvidiaMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\xf9\x01\n\x15GenerativeXAIMetadata\x12<\n\x05usage\x18\x01 \x01(\x0b\x32(.weaviate.v1.GenerativeXAIMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\x8f\x06\n\x12GenerativeMetadata\x12=\n\tanthropic\x18\x01 \x01(\x0b\x32(.weaviate.v1.GenerativeAnthropicMetadataH\x00\x12;\n\x08\x61nyscale\x18\x02 \x01(\x0b\x32\'.weaviate.v1.GenerativeAnyscaleMetadataH\x00\x12\x31\n\x03\x61ws\x18\x03 \x01(\x0b\x32\".weaviate.v1.GenerativeAWSMetadataH\x00\x12\x37\n\x06\x63ohere\x18\x04 \x01(\x0b\x32%.weaviate.v1.GenerativeCohereMetadataH\x00\x12\x35\n\x05\x64ummy\x18\x05 \x01(\x0b\x32$.weaviate.v1.GenerativeDummyMetadataH\x00\x12\x39\n\x07mistral\x18\x06 \x01(\x0b\x32&.weaviate.v1.GenerativeMistralMetadataH\x00\x12\x37\n\x06ollama\x18\x07 \x01(\x0b\x32%.weaviate.v1.GenerativeOllamaMetadataH\x00\x12\x37\n\x06openai\x18\x08 \x01(\x0b\x32%.weaviate.v1.GenerativeOpenAIMetadataH\x00\x12\x37\n\x06google\x18\t \x01(\x0b\x32%.weaviate.v1.GenerativeGoogleMetadataH\x00\x12?\n\ndatabricks\x18\n \x01(\x0b\x32).weaviate.v1.GenerativeDatabricksMetadataH\x00\x12?\n\nfriendliai\x18\x0b \x01(\x0b\x32).weaviate.v1.GenerativeFriendliAIMetadataH\x00\x12\x37\n\x06nvidia\x18\x0c \x01(\x0b\x32%.weaviate.v1.GenerativeNvidiaMetadataH\x00\x12\x31\n\x03xai\x18\r \x01(\x0b\x32\".weaviate.v1.GenerativeXAIMetadataH\x00\x42\x06\n\x04kind\"\xa2\x01\n\x0fGenerativeReply\x12\x0e\n\x06result\x18\x01 \x01(\t\x12\x30\n\x05\x64\x65\x62ug\x18\x02 \x01(\x0b\x32\x1c.weaviate.v1.GenerativeDebugH\x00\x88\x01\x01\x12\x36\n\x08metadata\x18\x03 \x01(\x0b\x32\x1f.weaviate.v1.GenerativeMetadataH\x01\x88\x01\x01\x42\x08\n\x06_debugB\x0b\n\t_metadata\"@\n\x10GenerativeResult\x12,\n\x06values\x18\x01 \x03(\x0b\x32\x1c.weaviate.v1.GenerativeReply\";\n\x0fGenerativeDebug\x12\x18\n\x0b\x66ull_prompt\x18\x01 \x01(\tH\x00\x88\x01\x01\x42\x0e\n\x0c_full_promptBt\n#io.weaviate.client.grpc.protocol.v1B\x17WeaviateProtoGenerativeZ4github.com/weaviate/weaviate/grpc/generated;protocolb\x06proto3') +DESCRIPTOR = _descriptor_pool.Default().AddSerializedFile(b'\n\x13v1/generative.proto\x12\x0bweaviate.v1\x1a\rv1/base.proto\"\xdd\x03\n\x10GenerativeSearch\x12\"\n\x16single_response_prompt\x18\x01 \x01(\tB\x02\x18\x01\x12!\n\x15grouped_response_task\x18\x02 \x01(\tB\x02\x18\x01\x12\x1e\n\x12grouped_properties\x18\x03 \x03(\tB\x02\x18\x01\x12\x34\n\x06single\x18\x04 \x01(\x0b\x32$.weaviate.v1.GenerativeSearch.Single\x12\x36\n\x07grouped\x18\x05 \x01(\x0b\x32%.weaviate.v1.GenerativeSearch.Grouped\x1aY\n\x06Single\x12\x0e\n\x06prompt\x18\x01 \x01(\t\x12\r\n\x05\x64\x65\x62ug\x18\x02 \x01(\x08\x12\x30\n\x07queries\x18\x03 \x03(\x0b\x32\x1f.weaviate.v1.GenerativeProvider\x1a\x98\x01\n\x07Grouped\x12\x0c\n\x04task\x18\x01 \x01(\t\x12/\n\nproperties\x18\x02 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x00\x88\x01\x01\x12\x30\n\x07queries\x18\x03 \x03(\x0b\x32\x1f.weaviate.v1.GenerativeProvider\x12\r\n\x05\x64\x65\x62ug\x18\x04 \x01(\x08\x42\r\n\x0b_properties\"\xfd\x05\n\x12GenerativeProvider\x12\x17\n\x0freturn_metadata\x18\x01 \x01(\x08\x12\x35\n\tanthropic\x18\x02 \x01(\x0b\x32 .weaviate.v1.GenerativeAnthropicH\x00\x12\x33\n\x08\x61nyscale\x18\x03 \x01(\x0b\x32\x1f.weaviate.v1.GenerativeAnyscaleH\x00\x12)\n\x03\x61ws\x18\x04 \x01(\x0b\x32\x1a.weaviate.v1.GenerativeAWSH\x00\x12/\n\x06\x63ohere\x18\x05 \x01(\x0b\x32\x1d.weaviate.v1.GenerativeCohereH\x00\x12-\n\x05\x64ummy\x18\x06 \x01(\x0b\x32\x1c.weaviate.v1.GenerativeDummyH\x00\x12\x31\n\x07mistral\x18\x07 \x01(\x0b\x32\x1e.weaviate.v1.GenerativeMistralH\x00\x12/\n\x06ollama\x18\x08 \x01(\x0b\x32\x1d.weaviate.v1.GenerativeOllamaH\x00\x12/\n\x06openai\x18\t \x01(\x0b\x32\x1d.weaviate.v1.GenerativeOpenAIH\x00\x12/\n\x06google\x18\n \x01(\x0b\x32\x1d.weaviate.v1.GenerativeGoogleH\x00\x12\x37\n\ndatabricks\x18\x0b \x01(\x0b\x32!.weaviate.v1.GenerativeDatabricksH\x00\x12\x37\n\nfriendliai\x18\x0c \x01(\x0b\x32!.weaviate.v1.GenerativeFriendliAIH\x00\x12/\n\x06nvidia\x18\r \x01(\x0b\x32\x1d.weaviate.v1.GenerativeNvidiaH\x00\x12)\n\x03xai\x18\x0e \x01(\x0b\x32\x1a.weaviate.v1.GenerativeXAIH\x00\x12;\n\x0c\x63ontextualai\x18\x0f \x01(\x0b\x32#.weaviate.v1.GenerativeContextualAIH\x00\x42\x06\n\x04kind\"\xb1\x03\n\x13GenerativeAnthropic\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x18\n\x0btemperature\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x12\n\x05top_k\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x12\n\x05top_p\x18\x06 \x01(\x01H\x05\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x07 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x06\x88\x01\x01\x12+\n\x06images\x18\x08 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x35\n\x10image_properties\x18\t \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x08\x88\x01\x01\x42\x0b\n\t_base_urlB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_kB\x08\n\x06_top_pB\x11\n\x0f_stop_sequencesB\t\n\x07_imagesB\x13\n\x11_image_properties\"\x80\x01\n\x12GenerativeAnyscale\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\x0e\n\x0c_temperature\"\x8d\x04\n\rGenerativeAWS\x12\x12\n\x05model\x18\x03 \x01(\tH\x00\x88\x01\x01\x12\x18\n\x0btemperature\x18\x08 \x01(\x01H\x01\x88\x01\x01\x12\x14\n\x07service\x18\t \x01(\tH\x02\x88\x01\x01\x12\x13\n\x06region\x18\n \x01(\tH\x03\x88\x01\x01\x12\x15\n\x08\x65ndpoint\x18\x0b \x01(\tH\x04\x88\x01\x01\x12\x19\n\x0ctarget_model\x18\x0c \x01(\tH\x05\x88\x01\x01\x12\x1b\n\x0etarget_variant\x18\r \x01(\tH\x06\x88\x01\x01\x12+\n\x06images\x18\x0e \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0f \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x08\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x10 \x01(\x03H\t\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x11 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\n\x88\x01\x01\x42\x08\n\x06_modelB\x0e\n\x0c_temperatureB\n\n\x08_serviceB\t\n\x07_regionB\x0b\n\t_endpointB\x0f\n\r_target_modelB\x11\n\x0f_target_variantB\t\n\x07_imagesB\x13\n\x11_image_propertiesB\r\n\x0b_max_tokensB\x11\n\x0f_stop_sequences\"\x88\x04\n\x10GenerativeCohere\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x1e\n\x11\x66requency_penalty\x18\x02 \x01(\x01H\x01\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x12\x12\n\x05model\x18\x04 \x01(\tH\x03\x88\x01\x01\x12\x0e\n\x01k\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x0e\n\x01p\x18\x06 \x01(\x01H\x05\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x07 \x01(\x01H\x06\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x08 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x18\n\x0btemperature\x18\t \x01(\x01H\x08\x88\x01\x01\x12+\n\x06images\x18\n \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\t\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0b \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\n\x88\x01\x01\x42\x0b\n\t_base_urlB\x14\n\x12_frequency_penaltyB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x04\n\x02_kB\x04\n\x02_pB\x13\n\x11_presence_penaltyB\x11\n\x0f_stop_sequencesB\x0e\n\x0c_temperatureB\t\n\x07_imagesB\x13\n\x11_image_properties\"\x11\n\x0fGenerativeDummy\"\xc5\x01\n\x11GenerativeMistral\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x18\n\x0btemperature\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x12\n\x05top_p\x18\x05 \x01(\x01H\x04\x88\x01\x01\x42\x0b\n\t_base_urlB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_p\"\x8a\x02\n\x10GenerativeOllama\x12\x19\n\x0c\x61pi_endpoint\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12+\n\x06images\x18\x04 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x03\x88\x01\x01\x12\x35\n\x10image_properties\x18\x05 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x04\x88\x01\x01\x42\x0f\n\r_api_endpointB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\t\n\x07_imagesB\x13\n\x11_image_properties\"\xe3\x08\n\x10GenerativeOpenAI\x12\x1e\n\x11\x66requency_penalty\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x0e\n\x01n\x18\x04 \x01(\x03H\x03\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x05 \x01(\x01H\x04\x88\x01\x01\x12)\n\x04stop\x18\x06 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x05\x88\x01\x01\x12\x18\n\x0btemperature\x18\x07 \x01(\x01H\x06\x88\x01\x01\x12\x12\n\x05top_p\x18\x08 \x01(\x01H\x07\x88\x01\x01\x12\x15\n\x08\x62\x61se_url\x18\t \x01(\tH\x08\x88\x01\x01\x12\x18\n\x0b\x61pi_version\x18\n \x01(\tH\t\x88\x01\x01\x12\x1a\n\rresource_name\x18\x0b \x01(\tH\n\x88\x01\x01\x12\x1a\n\rdeployment_id\x18\x0c \x01(\tH\x0b\x88\x01\x01\x12\x15\n\x08is_azure\x18\r \x01(\x08H\x0c\x88\x01\x01\x12+\n\x06images\x18\x0e \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\r\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0f \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x0e\x88\x01\x01\x12L\n\x10reasoning_effort\x18\x10 \x01(\x0e\x32-.weaviate.v1.GenerativeOpenAI.ReasoningEffortH\x0f\x88\x01\x01\x12?\n\tverbosity\x18\x11 \x01(\x0e\x32\'.weaviate.v1.GenerativeOpenAI.VerbosityH\x10\x88\x01\x01\"\xa3\x01\n\x0fReasoningEffort\x12 \n\x1cREASONING_EFFORT_UNSPECIFIED\x10\x00\x12\x1c\n\x18REASONING_EFFORT_MINIMAL\x10\x01\x12\x18\n\x14REASONING_EFFORT_LOW\x10\x02\x12\x1b\n\x17REASONING_EFFORT_MEDIUM\x10\x03\x12\x19\n\x15REASONING_EFFORT_HIGH\x10\x04\"c\n\tVerbosity\x12\x19\n\x15VERBOSITY_UNSPECIFIED\x10\x00\x12\x11\n\rVERBOSITY_LOW\x10\x01\x12\x14\n\x10VERBOSITY_MEDIUM\x10\x02\x12\x12\n\x0eVERBOSITY_HIGH\x10\x03\x42\x14\n\x12_frequency_penaltyB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x04\n\x02_nB\x13\n\x11_presence_penaltyB\x07\n\x05_stopB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\x0b\n\t_base_urlB\x0e\n\x0c_api_versionB\x10\n\x0e_resource_nameB\x10\n\x0e_deployment_idB\x0b\n\t_is_azureB\t\n\x07_imagesB\x13\n\x11_image_propertiesB\x13\n\x11_reasoning_effortB\x0c\n\n_verbosity\"\x92\x05\n\x10GenerativeGoogle\x12\x1e\n\x11\x66requency_penalty\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x18\n\x0btemperature\x18\x05 \x01(\x01H\x04\x88\x01\x01\x12\x12\n\x05top_k\x18\x06 \x01(\x03H\x05\x88\x01\x01\x12\x12\n\x05top_p\x18\x07 \x01(\x01H\x06\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x08 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x19\n\x0c\x61pi_endpoint\x18\t \x01(\tH\x08\x88\x01\x01\x12\x17\n\nproject_id\x18\n \x01(\tH\t\x88\x01\x01\x12\x18\n\x0b\x65ndpoint_id\x18\x0b \x01(\tH\n\x88\x01\x01\x12\x13\n\x06region\x18\x0c \x01(\tH\x0b\x88\x01\x01\x12+\n\x06images\x18\r \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x0c\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0e \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\r\x88\x01\x01\x42\x14\n\x12_frequency_penaltyB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x13\n\x11_presence_penaltyB\x0e\n\x0c_temperatureB\x08\n\x06_top_kB\x08\n\x06_top_pB\x11\n\x0f_stop_sequencesB\x0f\n\r_api_endpointB\r\n\x0b_project_idB\x0e\n\x0c_endpoint_idB\t\n\x07_regionB\t\n\x07_imagesB\x13\n\x11_image_properties\"\xd0\x03\n\x14GenerativeDatabricks\x12\x15\n\x08\x65ndpoint\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x1e\n\x11\x66requency_penalty\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x16\n\tlog_probs\x18\x04 \x01(\x08H\x03\x88\x01\x01\x12\x1a\n\rtop_log_probs\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x06 \x01(\x03H\x05\x88\x01\x01\x12\x0e\n\x01n\x18\x07 \x01(\x03H\x06\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x08 \x01(\x01H\x07\x88\x01\x01\x12)\n\x04stop\x18\t \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x08\x88\x01\x01\x12\x18\n\x0btemperature\x18\n \x01(\x01H\t\x88\x01\x01\x12\x12\n\x05top_p\x18\x0b \x01(\x01H\n\x88\x01\x01\x42\x0b\n\t_endpointB\x08\n\x06_modelB\x14\n\x12_frequency_penaltyB\x0c\n\n_log_probsB\x10\n\x0e_top_log_probsB\r\n\x0b_max_tokensB\x04\n\x02_nB\x13\n\x11_presence_penaltyB\x07\n\x05_stopB\x0e\n\x0c_temperatureB\x08\n\x06_top_p\"\xde\x01\n\x14GenerativeFriendliAI\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x12\x18\n\x0btemperature\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x0e\n\x01n\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x12\n\x05top_p\x18\x06 \x01(\x01H\x05\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\r\n\x0b_max_tokensB\x0e\n\x0c_temperatureB\x04\n\x02_nB\x08\n\x06_top_p\"\xc4\x01\n\x10GenerativeNvidia\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x12\n\x05top_p\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x05 \x01(\x03H\x04\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\r\n\x0b_max_tokens\"\xc5\x02\n\rGenerativeXAI\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x12\n\x05top_p\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12+\n\x06images\x18\x06 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x05\x88\x01\x01\x12\x35\n\x10image_properties\x18\x07 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x06\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\r\n\x0b_max_tokensB\t\n\x07_imagesB\x13\n\x11_image_properties\"\xce\x02\n\x16GenerativeContextualAI\x12\x12\n\x05model\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x18\n\x0btemperature\x18\x02 \x01(\x01H\x01\x88\x01\x01\x12\x12\n\x05top_p\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x1b\n\x0emax_new_tokens\x18\x04 \x01(\x03H\x03\x88\x01\x01\x12\x1a\n\rsystem_prompt\x18\x05 \x01(\tH\x04\x88\x01\x01\x12\x1d\n\x10\x61void_commentary\x18\x06 \x01(\x08H\x05\x88\x01\x01\x12.\n\tknowledge\x18\x07 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x06\x88\x01\x01\x42\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\x11\n\x0f_max_new_tokensB\x10\n\x0e_system_promptB\x13\n\x11_avoid_commentaryB\x0c\n\n_knowledge\"\x92\x01\n\x1bGenerativeAnthropicMetadata\x12=\n\x05usage\x18\x01 \x01(\x0b\x32..weaviate.v1.GenerativeAnthropicMetadata.Usage\x1a\x34\n\x05Usage\x12\x14\n\x0cinput_tokens\x18\x01 \x01(\x03\x12\x15\n\routput_tokens\x18\x02 \x01(\x03\"\x1c\n\x1aGenerativeAnyscaleMetadata\"\x17\n\x15GenerativeAWSMetadata\"\x9c\x06\n\x18GenerativeCohereMetadata\x12J\n\x0b\x61pi_version\x18\x01 \x01(\x0b\x32\x30.weaviate.v1.GenerativeCohereMetadata.ApiVersionH\x00\x88\x01\x01\x12L\n\x0c\x62illed_units\x18\x02 \x01(\x0b\x32\x31.weaviate.v1.GenerativeCohereMetadata.BilledUnitsH\x01\x88\x01\x01\x12\x41\n\x06tokens\x18\x03 \x01(\x0b\x32,.weaviate.v1.GenerativeCohereMetadata.TokensH\x02\x88\x01\x01\x12-\n\x08warnings\x18\x04 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x03\x88\x01\x01\x1a\x8e\x01\n\nApiVersion\x12\x14\n\x07version\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x1a\n\ris_deprecated\x18\x02 \x01(\x08H\x01\x88\x01\x01\x12\x1c\n\x0fis_experimental\x18\x03 \x01(\x08H\x02\x88\x01\x01\x42\n\n\x08_versionB\x10\n\x0e_is_deprecatedB\x12\n\x10_is_experimental\x1a\xc5\x01\n\x0b\x42illedUnits\x12\x19\n\x0cinput_tokens\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x1a\n\routput_tokens\x18\x02 \x01(\x01H\x01\x88\x01\x01\x12\x19\n\x0csearch_units\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x1c\n\x0f\x63lassifications\x18\x04 \x01(\x01H\x03\x88\x01\x01\x42\x0f\n\r_input_tokensB\x10\n\x0e_output_tokensB\x0f\n\r_search_unitsB\x12\n\x10_classifications\x1a\x62\n\x06Tokens\x12\x19\n\x0cinput_tokens\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x1a\n\routput_tokens\x18\x02 \x01(\x01H\x01\x88\x01\x01\x42\x0f\n\r_input_tokensB\x10\n\x0e_output_tokensB\x0e\n\x0c_api_versionB\x0f\n\r_billed_unitsB\t\n\x07_tokensB\x0b\n\t_warnings\"\x19\n\x17GenerativeDummyMetadata\"\x81\x02\n\x19GenerativeMistralMetadata\x12@\n\x05usage\x18\x01 \x01(\x0b\x32,.weaviate.v1.GenerativeMistralMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\x1a\n\x18GenerativeOllamaMetadata\"\xff\x01\n\x18GenerativeOpenAIMetadata\x12?\n\x05usage\x18\x01 \x01(\x0b\x32+.weaviate.v1.GenerativeOpenAIMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\xe8\x06\n\x18GenerativeGoogleMetadata\x12\x45\n\x08metadata\x18\x01 \x01(\x0b\x32..weaviate.v1.GenerativeGoogleMetadata.MetadataH\x00\x88\x01\x01\x12P\n\x0eusage_metadata\x18\x02 \x01(\x0b\x32\x33.weaviate.v1.GenerativeGoogleMetadata.UsageMetadataH\x01\x88\x01\x01\x1a~\n\nTokenCount\x12&\n\x19total_billable_characters\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x42\x1c\n\x1a_total_billable_charactersB\x0f\n\r_total_tokens\x1a\xe1\x01\n\rTokenMetadata\x12P\n\x11input_token_count\x18\x01 \x01(\x0b\x32\x30.weaviate.v1.GenerativeGoogleMetadata.TokenCountH\x00\x88\x01\x01\x12Q\n\x12output_token_count\x18\x02 \x01(\x0b\x32\x30.weaviate.v1.GenerativeGoogleMetadata.TokenCountH\x01\x88\x01\x01\x42\x14\n\x12_input_token_countB\x15\n\x13_output_token_count\x1ao\n\x08Metadata\x12P\n\x0etoken_metadata\x18\x01 \x01(\x0b\x32\x33.weaviate.v1.GenerativeGoogleMetadata.TokenMetadataH\x00\x88\x01\x01\x42\x11\n\x0f_token_metadata\x1a\xbd\x01\n\rUsageMetadata\x12\x1f\n\x12prompt_token_count\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12#\n\x16\x63\x61ndidates_token_count\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x1e\n\x11total_token_count\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x15\n\x13_prompt_token_countB\x19\n\x17_candidates_token_countB\x14\n\x12_total_token_countB\x0b\n\t_metadataB\x11\n\x0f_usage_metadata\"\x87\x02\n\x1cGenerativeDatabricksMetadata\x12\x43\n\x05usage\x18\x01 \x01(\x0b\x32/.weaviate.v1.GenerativeDatabricksMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\x87\x02\n\x1cGenerativeFriendliAIMetadata\x12\x43\n\x05usage\x18\x01 \x01(\x0b\x32/.weaviate.v1.GenerativeFriendliAIMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\xff\x01\n\x18GenerativeNvidiaMetadata\x12?\n\x05usage\x18\x01 \x01(\x0b\x32+.weaviate.v1.GenerativeNvidiaMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\xf9\x01\n\x15GenerativeXAIMetadata\x12<\n\x05usage\x18\x01 \x01(\x0b\x32(.weaviate.v1.GenerativeXAIMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\x8f\x06\n\x12GenerativeMetadata\x12=\n\tanthropic\x18\x01 \x01(\x0b\x32(.weaviate.v1.GenerativeAnthropicMetadataH\x00\x12;\n\x08\x61nyscale\x18\x02 \x01(\x0b\x32\'.weaviate.v1.GenerativeAnyscaleMetadataH\x00\x12\x31\n\x03\x61ws\x18\x03 \x01(\x0b\x32\".weaviate.v1.GenerativeAWSMetadataH\x00\x12\x37\n\x06\x63ohere\x18\x04 \x01(\x0b\x32%.weaviate.v1.GenerativeCohereMetadataH\x00\x12\x35\n\x05\x64ummy\x18\x05 \x01(\x0b\x32$.weaviate.v1.GenerativeDummyMetadataH\x00\x12\x39\n\x07mistral\x18\x06 \x01(\x0b\x32&.weaviate.v1.GenerativeMistralMetadataH\x00\x12\x37\n\x06ollama\x18\x07 \x01(\x0b\x32%.weaviate.v1.GenerativeOllamaMetadataH\x00\x12\x37\n\x06openai\x18\x08 \x01(\x0b\x32%.weaviate.v1.GenerativeOpenAIMetadataH\x00\x12\x37\n\x06google\x18\t \x01(\x0b\x32%.weaviate.v1.GenerativeGoogleMetadataH\x00\x12?\n\ndatabricks\x18\n \x01(\x0b\x32).weaviate.v1.GenerativeDatabricksMetadataH\x00\x12?\n\nfriendliai\x18\x0b \x01(\x0b\x32).weaviate.v1.GenerativeFriendliAIMetadataH\x00\x12\x37\n\x06nvidia\x18\x0c \x01(\x0b\x32%.weaviate.v1.GenerativeNvidiaMetadataH\x00\x12\x31\n\x03xai\x18\r \x01(\x0b\x32\".weaviate.v1.GenerativeXAIMetadataH\x00\x42\x06\n\x04kind\"\xa2\x01\n\x0fGenerativeReply\x12\x0e\n\x06result\x18\x01 \x01(\t\x12\x30\n\x05\x64\x65\x62ug\x18\x02 \x01(\x0b\x32\x1c.weaviate.v1.GenerativeDebugH\x00\x88\x01\x01\x12\x36\n\x08metadata\x18\x03 \x01(\x0b\x32\x1f.weaviate.v1.GenerativeMetadataH\x01\x88\x01\x01\x42\x08\n\x06_debugB\x0b\n\t_metadata\"@\n\x10GenerativeResult\x12,\n\x06values\x18\x01 \x03(\x0b\x32\x1c.weaviate.v1.GenerativeReply\";\n\x0fGenerativeDebug\x12\x18\n\x0b\x66ull_prompt\x18\x01 \x01(\tH\x00\x88\x01\x01\x42\x0e\n\x0c_full_promptBt\n#io.weaviate.client.grpc.protocol.v1B\x17WeaviateProtoGenerativeZ4github.com/weaviate/weaviate/grpc/generated;protocolb\x06proto3') _globals = globals() _builder.BuildMessageAndEnumDescriptors(DESCRIPTOR, _globals) @@ -42,93 +42,93 @@ _globals['_GENERATIVEANYSCALE']._serialized_start=1736 _globals['_GENERATIVEANYSCALE']._serialized_end=1864 _globals['_GENERATIVEAWS']._serialized_start=1867 - _globals['_GENERATIVEAWS']._serialized_end=2320 - _globals['_GENERATIVECOHERE']._serialized_start=2323 - _globals['_GENERATIVECOHERE']._serialized_end=2843 - _globals['_GENERATIVEDUMMY']._serialized_start=2845 - _globals['_GENERATIVEDUMMY']._serialized_end=2862 - _globals['_GENERATIVEMISTRAL']._serialized_start=2865 - _globals['_GENERATIVEMISTRAL']._serialized_end=3062 - _globals['_GENERATIVEOLLAMA']._serialized_start=3065 - _globals['_GENERATIVEOLLAMA']._serialized_end=3331 - _globals['_GENERATIVEOPENAI']._serialized_start=3334 - _globals['_GENERATIVEOPENAI']._serialized_end=4457 - _globals['_GENERATIVEOPENAI_REASONINGEFFORT']._serialized_start=3939 - _globals['_GENERATIVEOPENAI_REASONINGEFFORT']._serialized_end=4102 - _globals['_GENERATIVEOPENAI_VERBOSITY']._serialized_start=4104 - _globals['_GENERATIVEOPENAI_VERBOSITY']._serialized_end=4203 - _globals['_GENERATIVEGOOGLE']._serialized_start=4460 - _globals['_GENERATIVEGOOGLE']._serialized_end=5118 - _globals['_GENERATIVEDATABRICKS']._serialized_start=5121 - _globals['_GENERATIVEDATABRICKS']._serialized_end=5585 - _globals['_GENERATIVEFRIENDLIAI']._serialized_start=5588 - _globals['_GENERATIVEFRIENDLIAI']._serialized_end=5810 - _globals['_GENERATIVENVIDIA']._serialized_start=5813 - _globals['_GENERATIVENVIDIA']._serialized_end=6009 - _globals['_GENERATIVEXAI']._serialized_start=6012 - _globals['_GENERATIVEXAI']._serialized_end=6337 - _globals['_GENERATIVECONTEXTUALAI']._serialized_start=6340 - _globals['_GENERATIVECONTEXTUALAI']._serialized_end=6674 - _globals['_GENERATIVEANTHROPICMETADATA']._serialized_start=6677 - _globals['_GENERATIVEANTHROPICMETADATA']._serialized_end=6823 - _globals['_GENERATIVEANTHROPICMETADATA_USAGE']._serialized_start=6771 - _globals['_GENERATIVEANTHROPICMETADATA_USAGE']._serialized_end=6823 - _globals['_GENERATIVEANYSCALEMETADATA']._serialized_start=6825 - _globals['_GENERATIVEANYSCALEMETADATA']._serialized_end=6853 - _globals['_GENERATIVEAWSMETADATA']._serialized_start=6855 - _globals['_GENERATIVEAWSMETADATA']._serialized_end=6878 - _globals['_GENERATIVECOHEREMETADATA']._serialized_start=6881 - _globals['_GENERATIVECOHEREMETADATA']._serialized_end=7677 - _globals['_GENERATIVECOHEREMETADATA_APIVERSION']._serialized_start=7178 - _globals['_GENERATIVECOHEREMETADATA_APIVERSION']._serialized_end=7320 - _globals['_GENERATIVECOHEREMETADATA_BILLEDUNITS']._serialized_start=7323 - _globals['_GENERATIVECOHEREMETADATA_BILLEDUNITS']._serialized_end=7520 - _globals['_GENERATIVECOHEREMETADATA_TOKENS']._serialized_start=7522 - _globals['_GENERATIVECOHEREMETADATA_TOKENS']._serialized_end=7620 - _globals['_GENERATIVEDUMMYMETADATA']._serialized_start=7679 - _globals['_GENERATIVEDUMMYMETADATA']._serialized_end=7704 - _globals['_GENERATIVEMISTRALMETADATA']._serialized_start=7707 - _globals['_GENERATIVEMISTRALMETADATA']._serialized_end=7964 - _globals['_GENERATIVEMISTRALMETADATA_USAGE']._serialized_start=7803 - _globals['_GENERATIVEMISTRALMETADATA_USAGE']._serialized_end=7954 - _globals['_GENERATIVEOLLAMAMETADATA']._serialized_start=7966 - _globals['_GENERATIVEOLLAMAMETADATA']._serialized_end=7992 - _globals['_GENERATIVEOPENAIMETADATA']._serialized_start=7995 - _globals['_GENERATIVEOPENAIMETADATA']._serialized_end=8250 - _globals['_GENERATIVEOPENAIMETADATA_USAGE']._serialized_start=7803 - _globals['_GENERATIVEOPENAIMETADATA_USAGE']._serialized_end=7954 - _globals['_GENERATIVEGOOGLEMETADATA']._serialized_start=8253 - _globals['_GENERATIVEGOOGLEMETADATA']._serialized_end=9125 - _globals['_GENERATIVEGOOGLEMETADATA_TOKENCOUNT']._serialized_start=8434 - _globals['_GENERATIVEGOOGLEMETADATA_TOKENCOUNT']._serialized_end=8560 - _globals['_GENERATIVEGOOGLEMETADATA_TOKENMETADATA']._serialized_start=8563 - _globals['_GENERATIVEGOOGLEMETADATA_TOKENMETADATA']._serialized_end=8788 - _globals['_GENERATIVEGOOGLEMETADATA_METADATA']._serialized_start=8790 - _globals['_GENERATIVEGOOGLEMETADATA_METADATA']._serialized_end=8901 - _globals['_GENERATIVEGOOGLEMETADATA_USAGEMETADATA']._serialized_start=8904 - _globals['_GENERATIVEGOOGLEMETADATA_USAGEMETADATA']._serialized_end=9093 - _globals['_GENERATIVEDATABRICKSMETADATA']._serialized_start=9128 - _globals['_GENERATIVEDATABRICKSMETADATA']._serialized_end=9391 - _globals['_GENERATIVEDATABRICKSMETADATA_USAGE']._serialized_start=7803 - _globals['_GENERATIVEDATABRICKSMETADATA_USAGE']._serialized_end=7954 - _globals['_GENERATIVEFRIENDLIAIMETADATA']._serialized_start=9394 - _globals['_GENERATIVEFRIENDLIAIMETADATA']._serialized_end=9657 - _globals['_GENERATIVEFRIENDLIAIMETADATA_USAGE']._serialized_start=7803 - _globals['_GENERATIVEFRIENDLIAIMETADATA_USAGE']._serialized_end=7954 - _globals['_GENERATIVENVIDIAMETADATA']._serialized_start=9660 - _globals['_GENERATIVENVIDIAMETADATA']._serialized_end=9915 - _globals['_GENERATIVENVIDIAMETADATA_USAGE']._serialized_start=7803 - _globals['_GENERATIVENVIDIAMETADATA_USAGE']._serialized_end=7954 - _globals['_GENERATIVEXAIMETADATA']._serialized_start=9918 - _globals['_GENERATIVEXAIMETADATA']._serialized_end=10167 - _globals['_GENERATIVEXAIMETADATA_USAGE']._serialized_start=7803 - _globals['_GENERATIVEXAIMETADATA_USAGE']._serialized_end=7954 - _globals['_GENERATIVEMETADATA']._serialized_start=10170 - _globals['_GENERATIVEMETADATA']._serialized_end=10953 - _globals['_GENERATIVEREPLY']._serialized_start=10956 - _globals['_GENERATIVEREPLY']._serialized_end=11118 - _globals['_GENERATIVERESULT']._serialized_start=11120 - _globals['_GENERATIVERESULT']._serialized_end=11184 - _globals['_GENERATIVEDEBUG']._serialized_start=11186 - _globals['_GENERATIVEDEBUG']._serialized_end=11245 + _globals['_GENERATIVEAWS']._serialized_end=2392 + _globals['_GENERATIVECOHERE']._serialized_start=2395 + _globals['_GENERATIVECOHERE']._serialized_end=2915 + _globals['_GENERATIVEDUMMY']._serialized_start=2917 + _globals['_GENERATIVEDUMMY']._serialized_end=2934 + _globals['_GENERATIVEMISTRAL']._serialized_start=2937 + _globals['_GENERATIVEMISTRAL']._serialized_end=3134 + _globals['_GENERATIVEOLLAMA']._serialized_start=3137 + _globals['_GENERATIVEOLLAMA']._serialized_end=3403 + _globals['_GENERATIVEOPENAI']._serialized_start=3406 + _globals['_GENERATIVEOPENAI']._serialized_end=4529 + _globals['_GENERATIVEOPENAI_REASONINGEFFORT']._serialized_start=4011 + _globals['_GENERATIVEOPENAI_REASONINGEFFORT']._serialized_end=4174 + _globals['_GENERATIVEOPENAI_VERBOSITY']._serialized_start=4176 + _globals['_GENERATIVEOPENAI_VERBOSITY']._serialized_end=4275 + _globals['_GENERATIVEGOOGLE']._serialized_start=4532 + _globals['_GENERATIVEGOOGLE']._serialized_end=5190 + _globals['_GENERATIVEDATABRICKS']._serialized_start=5193 + _globals['_GENERATIVEDATABRICKS']._serialized_end=5657 + _globals['_GENERATIVEFRIENDLIAI']._serialized_start=5660 + _globals['_GENERATIVEFRIENDLIAI']._serialized_end=5882 + _globals['_GENERATIVENVIDIA']._serialized_start=5885 + _globals['_GENERATIVENVIDIA']._serialized_end=6081 + _globals['_GENERATIVEXAI']._serialized_start=6084 + _globals['_GENERATIVEXAI']._serialized_end=6409 + _globals['_GENERATIVECONTEXTUALAI']._serialized_start=6412 + _globals['_GENERATIVECONTEXTUALAI']._serialized_end=6746 + _globals['_GENERATIVEANTHROPICMETADATA']._serialized_start=6749 + _globals['_GENERATIVEANTHROPICMETADATA']._serialized_end=6895 + _globals['_GENERATIVEANTHROPICMETADATA_USAGE']._serialized_start=6843 + _globals['_GENERATIVEANTHROPICMETADATA_USAGE']._serialized_end=6895 + _globals['_GENERATIVEANYSCALEMETADATA']._serialized_start=6897 + _globals['_GENERATIVEANYSCALEMETADATA']._serialized_end=6925 + _globals['_GENERATIVEAWSMETADATA']._serialized_start=6927 + _globals['_GENERATIVEAWSMETADATA']._serialized_end=6950 + _globals['_GENERATIVECOHEREMETADATA']._serialized_start=6953 + _globals['_GENERATIVECOHEREMETADATA']._serialized_end=7749 + _globals['_GENERATIVECOHEREMETADATA_APIVERSION']._serialized_start=7250 + _globals['_GENERATIVECOHEREMETADATA_APIVERSION']._serialized_end=7392 + _globals['_GENERATIVECOHEREMETADATA_BILLEDUNITS']._serialized_start=7395 + _globals['_GENERATIVECOHEREMETADATA_BILLEDUNITS']._serialized_end=7592 + _globals['_GENERATIVECOHEREMETADATA_TOKENS']._serialized_start=7594 + _globals['_GENERATIVECOHEREMETADATA_TOKENS']._serialized_end=7692 + _globals['_GENERATIVEDUMMYMETADATA']._serialized_start=7751 + _globals['_GENERATIVEDUMMYMETADATA']._serialized_end=7776 + _globals['_GENERATIVEMISTRALMETADATA']._serialized_start=7779 + _globals['_GENERATIVEMISTRALMETADATA']._serialized_end=8036 + _globals['_GENERATIVEMISTRALMETADATA_USAGE']._serialized_start=7875 + _globals['_GENERATIVEMISTRALMETADATA_USAGE']._serialized_end=8026 + _globals['_GENERATIVEOLLAMAMETADATA']._serialized_start=8038 + _globals['_GENERATIVEOLLAMAMETADATA']._serialized_end=8064 + _globals['_GENERATIVEOPENAIMETADATA']._serialized_start=8067 + _globals['_GENERATIVEOPENAIMETADATA']._serialized_end=8322 + _globals['_GENERATIVEOPENAIMETADATA_USAGE']._serialized_start=7875 + _globals['_GENERATIVEOPENAIMETADATA_USAGE']._serialized_end=8026 + _globals['_GENERATIVEGOOGLEMETADATA']._serialized_start=8325 + _globals['_GENERATIVEGOOGLEMETADATA']._serialized_end=9197 + _globals['_GENERATIVEGOOGLEMETADATA_TOKENCOUNT']._serialized_start=8506 + _globals['_GENERATIVEGOOGLEMETADATA_TOKENCOUNT']._serialized_end=8632 + _globals['_GENERATIVEGOOGLEMETADATA_TOKENMETADATA']._serialized_start=8635 + _globals['_GENERATIVEGOOGLEMETADATA_TOKENMETADATA']._serialized_end=8860 + _globals['_GENERATIVEGOOGLEMETADATA_METADATA']._serialized_start=8862 + _globals['_GENERATIVEGOOGLEMETADATA_METADATA']._serialized_end=8973 + _globals['_GENERATIVEGOOGLEMETADATA_USAGEMETADATA']._serialized_start=8976 + _globals['_GENERATIVEGOOGLEMETADATA_USAGEMETADATA']._serialized_end=9165 + _globals['_GENERATIVEDATABRICKSMETADATA']._serialized_start=9200 + _globals['_GENERATIVEDATABRICKSMETADATA']._serialized_end=9463 + _globals['_GENERATIVEDATABRICKSMETADATA_USAGE']._serialized_start=7875 + _globals['_GENERATIVEDATABRICKSMETADATA_USAGE']._serialized_end=8026 + _globals['_GENERATIVEFRIENDLIAIMETADATA']._serialized_start=9466 + _globals['_GENERATIVEFRIENDLIAIMETADATA']._serialized_end=9729 + _globals['_GENERATIVEFRIENDLIAIMETADATA_USAGE']._serialized_start=7875 + _globals['_GENERATIVEFRIENDLIAIMETADATA_USAGE']._serialized_end=8026 + _globals['_GENERATIVENVIDIAMETADATA']._serialized_start=9732 + _globals['_GENERATIVENVIDIAMETADATA']._serialized_end=9987 + _globals['_GENERATIVENVIDIAMETADATA_USAGE']._serialized_start=7875 + _globals['_GENERATIVENVIDIAMETADATA_USAGE']._serialized_end=8026 + _globals['_GENERATIVEXAIMETADATA']._serialized_start=9990 + _globals['_GENERATIVEXAIMETADATA']._serialized_end=10239 + _globals['_GENERATIVEXAIMETADATA_USAGE']._serialized_start=7875 + _globals['_GENERATIVEXAIMETADATA_USAGE']._serialized_end=8026 + _globals['_GENERATIVEMETADATA']._serialized_start=10242 + _globals['_GENERATIVEMETADATA']._serialized_end=11025 + _globals['_GENERATIVEREPLY']._serialized_start=11028 + _globals['_GENERATIVEREPLY']._serialized_end=11190 + _globals['_GENERATIVERESULT']._serialized_start=11192 + _globals['_GENERATIVERESULT']._serialized_end=11256 + _globals['_GENERATIVEDEBUG']._serialized_start=11258 + _globals['_GENERATIVEDEBUG']._serialized_end=11317 # @@protoc_insertion_point(module_scope) diff --git a/weaviate/proto/v1/v5261/v1/generative_pb2.pyi b/weaviate/proto/v1/v5261/v1/generative_pb2.pyi index 5c0b563e5..1699c732f 100644 --- a/weaviate/proto/v1/v5261/v1/generative_pb2.pyi +++ b/weaviate/proto/v1/v5261/v1/generative_pb2.pyi @@ -108,7 +108,7 @@ class GenerativeAnyscale(_message.Message): def __init__(self, base_url: _Optional[str] = ..., model: _Optional[str] = ..., temperature: _Optional[float] = ...) -> None: ... class GenerativeAWS(_message.Message): - __slots__ = ("model", "temperature", "service", "region", "endpoint", "target_model", "target_variant", "images", "image_properties", "max_tokens") + __slots__ = ("model", "temperature", "service", "region", "endpoint", "target_model", "target_variant", "images", "image_properties", "max_tokens", "stop_sequences") MODEL_FIELD_NUMBER: _ClassVar[int] TEMPERATURE_FIELD_NUMBER: _ClassVar[int] SERVICE_FIELD_NUMBER: _ClassVar[int] @@ -119,6 +119,7 @@ class GenerativeAWS(_message.Message): IMAGES_FIELD_NUMBER: _ClassVar[int] IMAGE_PROPERTIES_FIELD_NUMBER: _ClassVar[int] MAX_TOKENS_FIELD_NUMBER: _ClassVar[int] + STOP_SEQUENCES_FIELD_NUMBER: _ClassVar[int] model: str temperature: float service: str @@ -129,7 +130,8 @@ class GenerativeAWS(_message.Message): images: _base_pb2.TextArray image_properties: _base_pb2.TextArray max_tokens: int - def __init__(self, model: _Optional[str] = ..., temperature: _Optional[float] = ..., service: _Optional[str] = ..., region: _Optional[str] = ..., endpoint: _Optional[str] = ..., target_model: _Optional[str] = ..., target_variant: _Optional[str] = ..., images: _Optional[_Union[_base_pb2.TextArray, _Mapping]] = ..., image_properties: _Optional[_Union[_base_pb2.TextArray, _Mapping]] = ..., max_tokens: _Optional[int] = ...) -> None: ... + stop_sequences: _base_pb2.TextArray + def __init__(self, model: _Optional[str] = ..., temperature: _Optional[float] = ..., service: _Optional[str] = ..., region: _Optional[str] = ..., endpoint: _Optional[str] = ..., target_model: _Optional[str] = ..., target_variant: _Optional[str] = ..., images: _Optional[_Union[_base_pb2.TextArray, _Mapping]] = ..., image_properties: _Optional[_Union[_base_pb2.TextArray, _Mapping]] = ..., max_tokens: _Optional[int] = ..., stop_sequences: _Optional[_Union[_base_pb2.TextArray, _Mapping]] = ...) -> None: ... class GenerativeCohere(_message.Message): __slots__ = ("base_url", "frequency_penalty", "max_tokens", "model", "k", "p", "presence_penalty", "stop_sequences", "temperature", "images", "image_properties") diff --git a/weaviate/proto/v1/v6300/v1/batch_pb2.py b/weaviate/proto/v1/v6300/v1/batch_pb2.py index f7434e1d3..83b37fd05 100644 --- a/weaviate/proto/v1/v6300/v1/batch_pb2.py +++ b/weaviate/proto/v1/v6300/v1/batch_pb2.py @@ -26,7 +26,7 @@ from weaviate.proto.v1.v6300.v1 import base_pb2 as v1_dot_base__pb2 -DESCRIPTOR = _descriptor_pool.Default().AddSerializedFile(b'\n\x0ev1/batch.proto\x12\x0bweaviate.v1\x1a\x1cgoogle/protobuf/struct.proto\x1a\rv1/base.proto\"\x95\x01\n\x13\x42\x61tchObjectsRequest\x12)\n\x07objects\x18\x01 \x03(\x0b\x32\x18.weaviate.v1.BatchObject\x12=\n\x11\x63onsistency_level\x18\x02 \x01(\x0e\x32\x1d.weaviate.v1.ConsistencyLevelH\x00\x88\x01\x01\x42\x14\n\x12_consistency_level\"\x9e\x01\n\x16\x42\x61tchReferencesRequest\x12/\n\nreferences\x18\x01 \x03(\x0b\x32\x1b.weaviate.v1.BatchReference\x12=\n\x11\x63onsistency_level\x18\x02 \x01(\x0e\x32\x1d.weaviate.v1.ConsistencyLevelH\x00\x88\x01\x01\x42\x14\n\x12_consistency_level\"\xa6\x04\n\x12\x42\x61tchStreamRequest\x12\x36\n\x05start\x18\x01 \x01(\x0b\x32%.weaviate.v1.BatchStreamRequest.StartH\x00\x12\x34\n\x04\x64\x61ta\x18\x02 \x01(\x0b\x32$.weaviate.v1.BatchStreamRequest.DataH\x00\x12\x34\n\x04stop\x18\x03 \x01(\x0b\x32$.weaviate.v1.BatchStreamRequest.StopH\x00\x1a\\\n\x05Start\x12=\n\x11\x63onsistency_level\x18\x01 \x01(\x0e\x32\x1d.weaviate.v1.ConsistencyLevelH\x00\x88\x01\x01\x42\x14\n\x12_consistency_level\x1a\x06\n\x04Stop\x1a\xfa\x01\n\x04\x44\x61ta\x12=\n\x07objects\x18\x01 \x01(\x0b\x32,.weaviate.v1.BatchStreamRequest.Data.Objects\x12\x43\n\nreferences\x18\x02 \x01(\x0b\x32/.weaviate.v1.BatchStreamRequest.Data.References\x1a\x33\n\x07Objects\x12(\n\x06values\x18\x01 \x03(\x0b\x32\x18.weaviate.v1.BatchObject\x1a\x39\n\nReferences\x12+\n\x06values\x18\x01 \x03(\x0b\x32\x1b.weaviate.v1.BatchReferenceB\t\n\x07message\"\x98\x05\n\x10\x42\x61tchStreamReply\x12\x38\n\x07results\x18\x01 \x01(\x0b\x32%.weaviate.v1.BatchStreamReply.ResultsH\x00\x12\x43\n\rshutting_down\x18\x02 \x01(\x0b\x32*.weaviate.v1.BatchStreamReply.ShuttingDownH\x00\x12:\n\x08shutdown\x18\x03 \x01(\x0b\x32&.weaviate.v1.BatchStreamReply.ShutdownH\x00\x12\x38\n\x07started\x18\x04 \x01(\x0b\x32%.weaviate.v1.BatchStreamReply.StartedH\x00\x12\x38\n\x07\x62\x61\x63koff\x18\x05 \x01(\x0b\x32%.weaviate.v1.BatchStreamReply.BackoffH\x00\x1a\t\n\x07Started\x1a\x0e\n\x0cShuttingDown\x1a\n\n\x08Shutdown\x1a\x1d\n\x07\x42\x61\x63koff\x12\x12\n\nbatch_size\x18\x01 \x01(\x05\x1a\x83\x02\n\x07Results\x12;\n\x06\x65rrors\x18\x01 \x03(\x0b\x32+.weaviate.v1.BatchStreamReply.Results.Error\x12@\n\tsuccesses\x18\x02 \x03(\x0b\x32-.weaviate.v1.BatchStreamReply.Results.Success\x1a\x42\n\x05\x45rror\x12\r\n\x05\x65rror\x18\x01 \x01(\t\x12\x0e\n\x04uuid\x18\x02 \x01(\tH\x00\x12\x10\n\x06\x62\x65\x61\x63on\x18\x03 \x01(\tH\x00\x42\x08\n\x06\x64\x65tail\x1a\x35\n\x07Success\x12\x0e\n\x04uuid\x18\x02 \x01(\tH\x00\x12\x10\n\x06\x62\x65\x61\x63on\x18\x03 \x01(\tH\x00\x42\x08\n\x06\x64\x65tailB\t\n\x07message\"\xde\x07\n\x0b\x42\x61tchObject\x12\x0c\n\x04uuid\x18\x01 \x01(\t\x12\x12\n\x06vector\x18\x02 \x03(\x02\x42\x02\x18\x01\x12\x37\n\nproperties\x18\x03 \x01(\x0b\x32#.weaviate.v1.BatchObject.Properties\x12\x12\n\ncollection\x18\x04 \x01(\t\x12\x0e\n\x06tenant\x18\x05 \x01(\t\x12\x14\n\x0cvector_bytes\x18\x06 \x01(\x0c\x12%\n\x07vectors\x18\x17 \x03(\x0b\x32\x14.weaviate.v1.Vectors\x1a\x84\x05\n\nProperties\x12\x33\n\x12non_ref_properties\x18\x01 \x01(\x0b\x32\x17.google.protobuf.Struct\x12N\n\x17single_target_ref_props\x18\x02 \x03(\x0b\x32-.weaviate.v1.BatchObject.SingleTargetRefProps\x12L\n\x16multi_target_ref_props\x18\x03 \x03(\x0b\x32,.weaviate.v1.BatchObject.MultiTargetRefProps\x12\x43\n\x17number_array_properties\x18\x04 \x03(\x0b\x32\".weaviate.v1.NumberArrayProperties\x12=\n\x14int_array_properties\x18\x05 \x03(\x0b\x32\x1f.weaviate.v1.IntArrayProperties\x12?\n\x15text_array_properties\x18\x06 \x03(\x0b\x32 .weaviate.v1.TextArrayProperties\x12\x45\n\x18\x62oolean_array_properties\x18\x07 \x03(\x0b\x32#.weaviate.v1.BooleanArrayProperties\x12\x38\n\x11object_properties\x18\x08 \x03(\x0b\x32\x1d.weaviate.v1.ObjectProperties\x12\x43\n\x17object_array_properties\x18\t \x03(\x0b\x32\".weaviate.v1.ObjectArrayProperties\x12\x18\n\x10\x65mpty_list_props\x18\n \x03(\t\x1a\x38\n\x14SingleTargetRefProps\x12\r\n\x05uuids\x18\x01 \x03(\t\x12\x11\n\tprop_name\x18\x02 \x01(\t\x1aR\n\x13MultiTargetRefProps\x12\r\n\x05uuids\x18\x01 \x03(\t\x12\x11\n\tprop_name\x18\x02 \x01(\t\x12\x19\n\x11target_collection\x18\x03 \x01(\t\"\x99\x01\n\x0e\x42\x61tchReference\x12\x0c\n\x04name\x18\x01 \x01(\t\x12\x17\n\x0f\x66rom_collection\x18\x02 \x01(\t\x12\x11\n\tfrom_uuid\x18\x03 \x01(\t\x12\x1a\n\rto_collection\x18\x04 \x01(\tH\x00\x88\x01\x01\x12\x0f\n\x07to_uuid\x18\x05 \x01(\t\x12\x0e\n\x06tenant\x18\x06 \x01(\tB\x10\n\x0e_to_collection\"\x88\x01\n\x11\x42\x61tchObjectsReply\x12\x0c\n\x04took\x18\x01 \x01(\x02\x12\x39\n\x06\x65rrors\x18\x02 \x03(\x0b\x32).weaviate.v1.BatchObjectsReply.BatchError\x1a*\n\nBatchError\x12\r\n\x05index\x18\x01 \x01(\x05\x12\r\n\x05\x65rror\x18\x02 \x01(\t\"\x8e\x01\n\x14\x42\x61tchReferencesReply\x12\x0c\n\x04took\x18\x01 \x01(\x02\x12<\n\x06\x65rrors\x18\x02 \x03(\x0b\x32,.weaviate.v1.BatchReferencesReply.BatchError\x1a*\n\nBatchError\x12\r\n\x05index\x18\x01 \x01(\x05\x12\r\n\x05\x65rror\x18\x02 \x01(\tBo\n#io.weaviate.client.grpc.protocol.v1B\x12WeaviateProtoBatchZ4github.com/weaviate/weaviate/grpc/generated;protocolb\x06proto3') +DESCRIPTOR = _descriptor_pool.Default().AddSerializedFile(b'\n\x0ev1/batch.proto\x12\x0bweaviate.v1\x1a\x1cgoogle/protobuf/struct.proto\x1a\rv1/base.proto\"\x95\x01\n\x13\x42\x61tchObjectsRequest\x12)\n\x07objects\x18\x01 \x03(\x0b\x32\x18.weaviate.v1.BatchObject\x12=\n\x11\x63onsistency_level\x18\x02 \x01(\x0e\x32\x1d.weaviate.v1.ConsistencyLevelH\x00\x88\x01\x01\x42\x14\n\x12_consistency_level\"\x9e\x01\n\x16\x42\x61tchReferencesRequest\x12/\n\nreferences\x18\x01 \x03(\x0b\x32\x1b.weaviate.v1.BatchReference\x12=\n\x11\x63onsistency_level\x18\x02 \x01(\x0e\x32\x1d.weaviate.v1.ConsistencyLevelH\x00\x88\x01\x01\x42\x14\n\x12_consistency_level\"\xa6\x04\n\x12\x42\x61tchStreamRequest\x12\x36\n\x05start\x18\x01 \x01(\x0b\x32%.weaviate.v1.BatchStreamRequest.StartH\x00\x12\x34\n\x04\x64\x61ta\x18\x02 \x01(\x0b\x32$.weaviate.v1.BatchStreamRequest.DataH\x00\x12\x34\n\x04stop\x18\x03 \x01(\x0b\x32$.weaviate.v1.BatchStreamRequest.StopH\x00\x1a\\\n\x05Start\x12=\n\x11\x63onsistency_level\x18\x01 \x01(\x0e\x32\x1d.weaviate.v1.ConsistencyLevelH\x00\x88\x01\x01\x42\x14\n\x12_consistency_level\x1a\x06\n\x04Stop\x1a\xfa\x01\n\x04\x44\x61ta\x12=\n\x07objects\x18\x01 \x01(\x0b\x32,.weaviate.v1.BatchStreamRequest.Data.Objects\x12\x43\n\nreferences\x18\x02 \x01(\x0b\x32/.weaviate.v1.BatchStreamRequest.Data.References\x1a\x33\n\x07Objects\x12(\n\x06values\x18\x01 \x03(\x0b\x32\x18.weaviate.v1.BatchObject\x1a\x39\n\nReferences\x12+\n\x06values\x18\x01 \x03(\x0b\x32\x1b.weaviate.v1.BatchReferenceB\t\n\x07message\"\xe7\x06\n\x10\x42\x61tchStreamReply\x12\x38\n\x07results\x18\x01 \x01(\x0b\x32%.weaviate.v1.BatchStreamReply.ResultsH\x00\x12\x43\n\rshutting_down\x18\x02 \x01(\x0b\x32*.weaviate.v1.BatchStreamReply.ShuttingDownH\x00\x12:\n\x08shutdown\x18\x03 \x01(\x0b\x32&.weaviate.v1.BatchStreamReply.ShutdownH\x00\x12\x38\n\x07started\x18\x04 \x01(\x0b\x32%.weaviate.v1.BatchStreamReply.StartedH\x00\x12\x38\n\x07\x62\x61\x63koff\x18\x05 \x01(\x0b\x32%.weaviate.v1.BatchStreamReply.BackoffH\x00\x12\x32\n\x04\x61\x63ks\x18\x06 \x01(\x0b\x32\".weaviate.v1.BatchStreamReply.AcksH\x00\x12\x42\n\rout_of_memory\x18\x07 \x01(\x0b\x32).weaviate.v1.BatchStreamReply.OutOfMemoryH\x00\x1a\t\n\x07Started\x1a\x0e\n\x0cShuttingDown\x1a\n\n\x08Shutdown\x1a-\n\x0bOutOfMemory\x12\r\n\x05uuids\x18\x01 \x03(\t\x12\x0f\n\x07\x62\x65\x61\x63ons\x18\x02 \x03(\t\x1a\x1d\n\x07\x42\x61\x63koff\x12\x12\n\nbatch_size\x18\x01 \x01(\x05\x1a&\n\x04\x41\x63ks\x12\r\n\x05uuids\x18\x01 \x03(\t\x12\x0f\n\x07\x62\x65\x61\x63ons\x18\x02 \x03(\t\x1a\x83\x02\n\x07Results\x12;\n\x06\x65rrors\x18\x01 \x03(\x0b\x32+.weaviate.v1.BatchStreamReply.Results.Error\x12@\n\tsuccesses\x18\x02 \x03(\x0b\x32-.weaviate.v1.BatchStreamReply.Results.Success\x1a\x42\n\x05\x45rror\x12\r\n\x05\x65rror\x18\x01 \x01(\t\x12\x0e\n\x04uuid\x18\x02 \x01(\tH\x00\x12\x10\n\x06\x62\x65\x61\x63on\x18\x03 \x01(\tH\x00\x42\x08\n\x06\x64\x65tail\x1a\x35\n\x07Success\x12\x0e\n\x04uuid\x18\x02 \x01(\tH\x00\x12\x10\n\x06\x62\x65\x61\x63on\x18\x03 \x01(\tH\x00\x42\x08\n\x06\x64\x65tailB\t\n\x07message\"\xde\x07\n\x0b\x42\x61tchObject\x12\x0c\n\x04uuid\x18\x01 \x01(\t\x12\x12\n\x06vector\x18\x02 \x03(\x02\x42\x02\x18\x01\x12\x37\n\nproperties\x18\x03 \x01(\x0b\x32#.weaviate.v1.BatchObject.Properties\x12\x12\n\ncollection\x18\x04 \x01(\t\x12\x0e\n\x06tenant\x18\x05 \x01(\t\x12\x14\n\x0cvector_bytes\x18\x06 \x01(\x0c\x12%\n\x07vectors\x18\x17 \x03(\x0b\x32\x14.weaviate.v1.Vectors\x1a\x84\x05\n\nProperties\x12\x33\n\x12non_ref_properties\x18\x01 \x01(\x0b\x32\x17.google.protobuf.Struct\x12N\n\x17single_target_ref_props\x18\x02 \x03(\x0b\x32-.weaviate.v1.BatchObject.SingleTargetRefProps\x12L\n\x16multi_target_ref_props\x18\x03 \x03(\x0b\x32,.weaviate.v1.BatchObject.MultiTargetRefProps\x12\x43\n\x17number_array_properties\x18\x04 \x03(\x0b\x32\".weaviate.v1.NumberArrayProperties\x12=\n\x14int_array_properties\x18\x05 \x03(\x0b\x32\x1f.weaviate.v1.IntArrayProperties\x12?\n\x15text_array_properties\x18\x06 \x03(\x0b\x32 .weaviate.v1.TextArrayProperties\x12\x45\n\x18\x62oolean_array_properties\x18\x07 \x03(\x0b\x32#.weaviate.v1.BooleanArrayProperties\x12\x38\n\x11object_properties\x18\x08 \x03(\x0b\x32\x1d.weaviate.v1.ObjectProperties\x12\x43\n\x17object_array_properties\x18\t \x03(\x0b\x32\".weaviate.v1.ObjectArrayProperties\x12\x18\n\x10\x65mpty_list_props\x18\n \x03(\t\x1a\x38\n\x14SingleTargetRefProps\x12\r\n\x05uuids\x18\x01 \x03(\t\x12\x11\n\tprop_name\x18\x02 \x01(\t\x1aR\n\x13MultiTargetRefProps\x12\r\n\x05uuids\x18\x01 \x03(\t\x12\x11\n\tprop_name\x18\x02 \x01(\t\x12\x19\n\x11target_collection\x18\x03 \x01(\t\"\x99\x01\n\x0e\x42\x61tchReference\x12\x0c\n\x04name\x18\x01 \x01(\t\x12\x17\n\x0f\x66rom_collection\x18\x02 \x01(\t\x12\x11\n\tfrom_uuid\x18\x03 \x01(\t\x12\x1a\n\rto_collection\x18\x04 \x01(\tH\x00\x88\x01\x01\x12\x0f\n\x07to_uuid\x18\x05 \x01(\t\x12\x0e\n\x06tenant\x18\x06 \x01(\tB\x10\n\x0e_to_collection\"\x88\x01\n\x11\x42\x61tchObjectsReply\x12\x0c\n\x04took\x18\x01 \x01(\x02\x12\x39\n\x06\x65rrors\x18\x02 \x03(\x0b\x32).weaviate.v1.BatchObjectsReply.BatchError\x1a*\n\nBatchError\x12\r\n\x05index\x18\x01 \x01(\x05\x12\r\n\x05\x65rror\x18\x02 \x01(\t\"\x8e\x01\n\x14\x42\x61tchReferencesReply\x12\x0c\n\x04took\x18\x01 \x01(\x02\x12<\n\x06\x65rrors\x18\x02 \x03(\x0b\x32,.weaviate.v1.BatchReferencesReply.BatchError\x1a*\n\nBatchError\x12\r\n\x05index\x18\x01 \x01(\x05\x12\r\n\x05\x65rror\x18\x02 \x01(\tBo\n#io.weaviate.client.grpc.protocol.v1B\x12WeaviateProtoBatchZ4github.com/weaviate/weaviate/grpc/generated;protocolb\x06proto3') _globals = globals() _builder.BuildMessageAndEnumDescriptors(DESCRIPTOR, _globals) @@ -53,37 +53,41 @@ _globals['_BATCHSTREAMREQUEST_DATA_REFERENCES']._serialized_start=872 _globals['_BATCHSTREAMREQUEST_DATA_REFERENCES']._serialized_end=929 _globals['_BATCHSTREAMREPLY']._serialized_start=943 - _globals['_BATCHSTREAMREPLY']._serialized_end=1607 - _globals['_BATCHSTREAMREPLY_STARTED']._serialized_start=1266 - _globals['_BATCHSTREAMREPLY_STARTED']._serialized_end=1275 - _globals['_BATCHSTREAMREPLY_SHUTTINGDOWN']._serialized_start=1277 - _globals['_BATCHSTREAMREPLY_SHUTTINGDOWN']._serialized_end=1291 - _globals['_BATCHSTREAMREPLY_SHUTDOWN']._serialized_start=1293 - _globals['_BATCHSTREAMREPLY_SHUTDOWN']._serialized_end=1303 - _globals['_BATCHSTREAMREPLY_BACKOFF']._serialized_start=1305 - _globals['_BATCHSTREAMREPLY_BACKOFF']._serialized_end=1334 - _globals['_BATCHSTREAMREPLY_RESULTS']._serialized_start=1337 - _globals['_BATCHSTREAMREPLY_RESULTS']._serialized_end=1596 - _globals['_BATCHSTREAMREPLY_RESULTS_ERROR']._serialized_start=1475 - _globals['_BATCHSTREAMREPLY_RESULTS_ERROR']._serialized_end=1541 - _globals['_BATCHSTREAMREPLY_RESULTS_SUCCESS']._serialized_start=1543 - _globals['_BATCHSTREAMREPLY_RESULTS_SUCCESS']._serialized_end=1596 - _globals['_BATCHOBJECT']._serialized_start=1610 - _globals['_BATCHOBJECT']._serialized_end=2600 - _globals['_BATCHOBJECT_PROPERTIES']._serialized_start=1814 - _globals['_BATCHOBJECT_PROPERTIES']._serialized_end=2458 - _globals['_BATCHOBJECT_SINGLETARGETREFPROPS']._serialized_start=2460 - _globals['_BATCHOBJECT_SINGLETARGETREFPROPS']._serialized_end=2516 - _globals['_BATCHOBJECT_MULTITARGETREFPROPS']._serialized_start=2518 - _globals['_BATCHOBJECT_MULTITARGETREFPROPS']._serialized_end=2600 - _globals['_BATCHREFERENCE']._serialized_start=2603 - _globals['_BATCHREFERENCE']._serialized_end=2756 - _globals['_BATCHOBJECTSREPLY']._serialized_start=2759 - _globals['_BATCHOBJECTSREPLY']._serialized_end=2895 - _globals['_BATCHOBJECTSREPLY_BATCHERROR']._serialized_start=2853 - _globals['_BATCHOBJECTSREPLY_BATCHERROR']._serialized_end=2895 - _globals['_BATCHREFERENCESREPLY']._serialized_start=2898 - _globals['_BATCHREFERENCESREPLY']._serialized_end=3040 - _globals['_BATCHREFERENCESREPLY_BATCHERROR']._serialized_start=2853 - _globals['_BATCHREFERENCESREPLY_BATCHERROR']._serialized_end=2895 + _globals['_BATCHSTREAMREPLY']._serialized_end=1814 + _globals['_BATCHSTREAMREPLY_STARTED']._serialized_start=1386 + _globals['_BATCHSTREAMREPLY_STARTED']._serialized_end=1395 + _globals['_BATCHSTREAMREPLY_SHUTTINGDOWN']._serialized_start=1397 + _globals['_BATCHSTREAMREPLY_SHUTTINGDOWN']._serialized_end=1411 + _globals['_BATCHSTREAMREPLY_SHUTDOWN']._serialized_start=1413 + _globals['_BATCHSTREAMREPLY_SHUTDOWN']._serialized_end=1423 + _globals['_BATCHSTREAMREPLY_OUTOFMEMORY']._serialized_start=1425 + _globals['_BATCHSTREAMREPLY_OUTOFMEMORY']._serialized_end=1470 + _globals['_BATCHSTREAMREPLY_BACKOFF']._serialized_start=1472 + _globals['_BATCHSTREAMREPLY_BACKOFF']._serialized_end=1501 + _globals['_BATCHSTREAMREPLY_ACKS']._serialized_start=1503 + _globals['_BATCHSTREAMREPLY_ACKS']._serialized_end=1541 + _globals['_BATCHSTREAMREPLY_RESULTS']._serialized_start=1544 + _globals['_BATCHSTREAMREPLY_RESULTS']._serialized_end=1803 + _globals['_BATCHSTREAMREPLY_RESULTS_ERROR']._serialized_start=1682 + _globals['_BATCHSTREAMREPLY_RESULTS_ERROR']._serialized_end=1748 + _globals['_BATCHSTREAMREPLY_RESULTS_SUCCESS']._serialized_start=1750 + _globals['_BATCHSTREAMREPLY_RESULTS_SUCCESS']._serialized_end=1803 + _globals['_BATCHOBJECT']._serialized_start=1817 + _globals['_BATCHOBJECT']._serialized_end=2807 + _globals['_BATCHOBJECT_PROPERTIES']._serialized_start=2021 + _globals['_BATCHOBJECT_PROPERTIES']._serialized_end=2665 + _globals['_BATCHOBJECT_SINGLETARGETREFPROPS']._serialized_start=2667 + _globals['_BATCHOBJECT_SINGLETARGETREFPROPS']._serialized_end=2723 + _globals['_BATCHOBJECT_MULTITARGETREFPROPS']._serialized_start=2725 + _globals['_BATCHOBJECT_MULTITARGETREFPROPS']._serialized_end=2807 + _globals['_BATCHREFERENCE']._serialized_start=2810 + _globals['_BATCHREFERENCE']._serialized_end=2963 + _globals['_BATCHOBJECTSREPLY']._serialized_start=2966 + _globals['_BATCHOBJECTSREPLY']._serialized_end=3102 + _globals['_BATCHOBJECTSREPLY_BATCHERROR']._serialized_start=3060 + _globals['_BATCHOBJECTSREPLY_BATCHERROR']._serialized_end=3102 + _globals['_BATCHREFERENCESREPLY']._serialized_start=3105 + _globals['_BATCHREFERENCESREPLY']._serialized_end=3247 + _globals['_BATCHREFERENCESREPLY_BATCHERROR']._serialized_start=3060 + _globals['_BATCHREFERENCESREPLY_BATCHERROR']._serialized_end=3102 # @@protoc_insertion_point(module_scope) diff --git a/weaviate/proto/v1/v6300/v1/batch_pb2.pyi b/weaviate/proto/v1/v6300/v1/batch_pb2.pyi index aa308b1d4..3a34d9b16 100644 --- a/weaviate/proto/v1/v6300/v1/batch_pb2.pyi +++ b/weaviate/proto/v1/v6300/v1/batch_pb2.pyi @@ -60,7 +60,7 @@ class BatchStreamRequest(_message.Message): def __init__(self, start: _Optional[_Union[BatchStreamRequest.Start, _Mapping]] = ..., data: _Optional[_Union[BatchStreamRequest.Data, _Mapping]] = ..., stop: _Optional[_Union[BatchStreamRequest.Stop, _Mapping]] = ...) -> None: ... class BatchStreamReply(_message.Message): - __slots__ = ("results", "shutting_down", "shutdown", "started", "backoff") + __slots__ = ("results", "shutting_down", "shutdown", "started", "backoff", "acks", "out_of_memory") class Started(_message.Message): __slots__ = () def __init__(self) -> None: ... @@ -70,11 +70,25 @@ class BatchStreamReply(_message.Message): class Shutdown(_message.Message): __slots__ = () def __init__(self) -> None: ... + class OutOfMemory(_message.Message): + __slots__ = ("uuids", "beacons") + UUIDS_FIELD_NUMBER: _ClassVar[int] + BEACONS_FIELD_NUMBER: _ClassVar[int] + uuids: _containers.RepeatedScalarFieldContainer[str] + beacons: _containers.RepeatedScalarFieldContainer[str] + def __init__(self, uuids: _Optional[_Iterable[str]] = ..., beacons: _Optional[_Iterable[str]] = ...) -> None: ... class Backoff(_message.Message): __slots__ = ("batch_size",) BATCH_SIZE_FIELD_NUMBER: _ClassVar[int] batch_size: int def __init__(self, batch_size: _Optional[int] = ...) -> None: ... + class Acks(_message.Message): + __slots__ = ("uuids", "beacons") + UUIDS_FIELD_NUMBER: _ClassVar[int] + BEACONS_FIELD_NUMBER: _ClassVar[int] + uuids: _containers.RepeatedScalarFieldContainer[str] + beacons: _containers.RepeatedScalarFieldContainer[str] + def __init__(self, uuids: _Optional[_Iterable[str]] = ..., beacons: _Optional[_Iterable[str]] = ...) -> None: ... class Results(_message.Message): __slots__ = ("errors", "successes") class Error(_message.Message): @@ -103,12 +117,16 @@ class BatchStreamReply(_message.Message): SHUTDOWN_FIELD_NUMBER: _ClassVar[int] STARTED_FIELD_NUMBER: _ClassVar[int] BACKOFF_FIELD_NUMBER: _ClassVar[int] + ACKS_FIELD_NUMBER: _ClassVar[int] + OUT_OF_MEMORY_FIELD_NUMBER: _ClassVar[int] results: BatchStreamReply.Results shutting_down: BatchStreamReply.ShuttingDown shutdown: BatchStreamReply.Shutdown started: BatchStreamReply.Started backoff: BatchStreamReply.Backoff - def __init__(self, results: _Optional[_Union[BatchStreamReply.Results, _Mapping]] = ..., shutting_down: _Optional[_Union[BatchStreamReply.ShuttingDown, _Mapping]] = ..., shutdown: _Optional[_Union[BatchStreamReply.Shutdown, _Mapping]] = ..., started: _Optional[_Union[BatchStreamReply.Started, _Mapping]] = ..., backoff: _Optional[_Union[BatchStreamReply.Backoff, _Mapping]] = ...) -> None: ... + acks: BatchStreamReply.Acks + out_of_memory: BatchStreamReply.OutOfMemory + def __init__(self, results: _Optional[_Union[BatchStreamReply.Results, _Mapping]] = ..., shutting_down: _Optional[_Union[BatchStreamReply.ShuttingDown, _Mapping]] = ..., shutdown: _Optional[_Union[BatchStreamReply.Shutdown, _Mapping]] = ..., started: _Optional[_Union[BatchStreamReply.Started, _Mapping]] = ..., backoff: _Optional[_Union[BatchStreamReply.Backoff, _Mapping]] = ..., acks: _Optional[_Union[BatchStreamReply.Acks, _Mapping]] = ..., out_of_memory: _Optional[_Union[BatchStreamReply.OutOfMemory, _Mapping]] = ...) -> None: ... class BatchObject(_message.Message): __slots__ = ("uuid", "vector", "properties", "collection", "tenant", "vector_bytes", "vectors") diff --git a/weaviate/proto/v1/v6300/v1/generative_pb2.py b/weaviate/proto/v1/v6300/v1/generative_pb2.py index 59337afe2..4af6fb9ce 100644 --- a/weaviate/proto/v1/v6300/v1/generative_pb2.py +++ b/weaviate/proto/v1/v6300/v1/generative_pb2.py @@ -25,7 +25,7 @@ from weaviate.proto.v1.v6300.v1 import base_pb2 as v1_dot_base__pb2 -DESCRIPTOR = _descriptor_pool.Default().AddSerializedFile(b'\n\x13v1/generative.proto\x12\x0bweaviate.v1\x1a\rv1/base.proto\"\xdd\x03\n\x10GenerativeSearch\x12\"\n\x16single_response_prompt\x18\x01 \x01(\tB\x02\x18\x01\x12!\n\x15grouped_response_task\x18\x02 \x01(\tB\x02\x18\x01\x12\x1e\n\x12grouped_properties\x18\x03 \x03(\tB\x02\x18\x01\x12\x34\n\x06single\x18\x04 \x01(\x0b\x32$.weaviate.v1.GenerativeSearch.Single\x12\x36\n\x07grouped\x18\x05 \x01(\x0b\x32%.weaviate.v1.GenerativeSearch.Grouped\x1aY\n\x06Single\x12\x0e\n\x06prompt\x18\x01 \x01(\t\x12\r\n\x05\x64\x65\x62ug\x18\x02 \x01(\x08\x12\x30\n\x07queries\x18\x03 \x03(\x0b\x32\x1f.weaviate.v1.GenerativeProvider\x1a\x98\x01\n\x07Grouped\x12\x0c\n\x04task\x18\x01 \x01(\t\x12/\n\nproperties\x18\x02 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x00\x88\x01\x01\x12\x30\n\x07queries\x18\x03 \x03(\x0b\x32\x1f.weaviate.v1.GenerativeProvider\x12\r\n\x05\x64\x65\x62ug\x18\x04 \x01(\x08\x42\r\n\x0b_properties\"\xfd\x05\n\x12GenerativeProvider\x12\x17\n\x0freturn_metadata\x18\x01 \x01(\x08\x12\x35\n\tanthropic\x18\x02 \x01(\x0b\x32 .weaviate.v1.GenerativeAnthropicH\x00\x12\x33\n\x08\x61nyscale\x18\x03 \x01(\x0b\x32\x1f.weaviate.v1.GenerativeAnyscaleH\x00\x12)\n\x03\x61ws\x18\x04 \x01(\x0b\x32\x1a.weaviate.v1.GenerativeAWSH\x00\x12/\n\x06\x63ohere\x18\x05 \x01(\x0b\x32\x1d.weaviate.v1.GenerativeCohereH\x00\x12-\n\x05\x64ummy\x18\x06 \x01(\x0b\x32\x1c.weaviate.v1.GenerativeDummyH\x00\x12\x31\n\x07mistral\x18\x07 \x01(\x0b\x32\x1e.weaviate.v1.GenerativeMistralH\x00\x12/\n\x06ollama\x18\x08 \x01(\x0b\x32\x1d.weaviate.v1.GenerativeOllamaH\x00\x12/\n\x06openai\x18\t \x01(\x0b\x32\x1d.weaviate.v1.GenerativeOpenAIH\x00\x12/\n\x06google\x18\n \x01(\x0b\x32\x1d.weaviate.v1.GenerativeGoogleH\x00\x12\x37\n\ndatabricks\x18\x0b \x01(\x0b\x32!.weaviate.v1.GenerativeDatabricksH\x00\x12\x37\n\nfriendliai\x18\x0c \x01(\x0b\x32!.weaviate.v1.GenerativeFriendliAIH\x00\x12/\n\x06nvidia\x18\r \x01(\x0b\x32\x1d.weaviate.v1.GenerativeNvidiaH\x00\x12)\n\x03xai\x18\x0e \x01(\x0b\x32\x1a.weaviate.v1.GenerativeXAIH\x00\x12;\n\x0c\x63ontextualai\x18\x0f \x01(\x0b\x32#.weaviate.v1.GenerativeContextualAIH\x00\x42\x06\n\x04kind\"\xb1\x03\n\x13GenerativeAnthropic\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x18\n\x0btemperature\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x12\n\x05top_k\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x12\n\x05top_p\x18\x06 \x01(\x01H\x05\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x07 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x06\x88\x01\x01\x12+\n\x06images\x18\x08 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x35\n\x10image_properties\x18\t \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x08\x88\x01\x01\x42\x0b\n\t_base_urlB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_kB\x08\n\x06_top_pB\x11\n\x0f_stop_sequencesB\t\n\x07_imagesB\x13\n\x11_image_properties\"\x80\x01\n\x12GenerativeAnyscale\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\x0e\n\x0c_temperature\"\xc5\x03\n\rGenerativeAWS\x12\x12\n\x05model\x18\x03 \x01(\tH\x00\x88\x01\x01\x12\x18\n\x0btemperature\x18\x08 \x01(\x01H\x01\x88\x01\x01\x12\x14\n\x07service\x18\t \x01(\tH\x02\x88\x01\x01\x12\x13\n\x06region\x18\n \x01(\tH\x03\x88\x01\x01\x12\x15\n\x08\x65ndpoint\x18\x0b \x01(\tH\x04\x88\x01\x01\x12\x19\n\x0ctarget_model\x18\x0c \x01(\tH\x05\x88\x01\x01\x12\x1b\n\x0etarget_variant\x18\r \x01(\tH\x06\x88\x01\x01\x12+\n\x06images\x18\x0e \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0f \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x08\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x10 \x01(\x03H\t\x88\x01\x01\x42\x08\n\x06_modelB\x0e\n\x0c_temperatureB\n\n\x08_serviceB\t\n\x07_regionB\x0b\n\t_endpointB\x0f\n\r_target_modelB\x11\n\x0f_target_variantB\t\n\x07_imagesB\x13\n\x11_image_propertiesB\r\n\x0b_max_tokens\"\x88\x04\n\x10GenerativeCohere\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x1e\n\x11\x66requency_penalty\x18\x02 \x01(\x01H\x01\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x12\x12\n\x05model\x18\x04 \x01(\tH\x03\x88\x01\x01\x12\x0e\n\x01k\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x0e\n\x01p\x18\x06 \x01(\x01H\x05\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x07 \x01(\x01H\x06\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x08 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x18\n\x0btemperature\x18\t \x01(\x01H\x08\x88\x01\x01\x12+\n\x06images\x18\n \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\t\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0b \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\n\x88\x01\x01\x42\x0b\n\t_base_urlB\x14\n\x12_frequency_penaltyB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x04\n\x02_kB\x04\n\x02_pB\x13\n\x11_presence_penaltyB\x11\n\x0f_stop_sequencesB\x0e\n\x0c_temperatureB\t\n\x07_imagesB\x13\n\x11_image_properties\"\x11\n\x0fGenerativeDummy\"\xc5\x01\n\x11GenerativeMistral\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x18\n\x0btemperature\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x12\n\x05top_p\x18\x05 \x01(\x01H\x04\x88\x01\x01\x42\x0b\n\t_base_urlB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_p\"\x8a\x02\n\x10GenerativeOllama\x12\x19\n\x0c\x61pi_endpoint\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12+\n\x06images\x18\x04 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x03\x88\x01\x01\x12\x35\n\x10image_properties\x18\x05 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x04\x88\x01\x01\x42\x0f\n\r_api_endpointB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\t\n\x07_imagesB\x13\n\x11_image_properties\"\xe3\x08\n\x10GenerativeOpenAI\x12\x1e\n\x11\x66requency_penalty\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x0e\n\x01n\x18\x04 \x01(\x03H\x03\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x05 \x01(\x01H\x04\x88\x01\x01\x12)\n\x04stop\x18\x06 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x05\x88\x01\x01\x12\x18\n\x0btemperature\x18\x07 \x01(\x01H\x06\x88\x01\x01\x12\x12\n\x05top_p\x18\x08 \x01(\x01H\x07\x88\x01\x01\x12\x15\n\x08\x62\x61se_url\x18\t \x01(\tH\x08\x88\x01\x01\x12\x18\n\x0b\x61pi_version\x18\n \x01(\tH\t\x88\x01\x01\x12\x1a\n\rresource_name\x18\x0b \x01(\tH\n\x88\x01\x01\x12\x1a\n\rdeployment_id\x18\x0c \x01(\tH\x0b\x88\x01\x01\x12\x15\n\x08is_azure\x18\r \x01(\x08H\x0c\x88\x01\x01\x12+\n\x06images\x18\x0e \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\r\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0f \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x0e\x88\x01\x01\x12L\n\x10reasoning_effort\x18\x10 \x01(\x0e\x32-.weaviate.v1.GenerativeOpenAI.ReasoningEffortH\x0f\x88\x01\x01\x12?\n\tverbosity\x18\x11 \x01(\x0e\x32\'.weaviate.v1.GenerativeOpenAI.VerbosityH\x10\x88\x01\x01\"\xa3\x01\n\x0fReasoningEffort\x12 \n\x1cREASONING_EFFORT_UNSPECIFIED\x10\x00\x12\x1c\n\x18REASONING_EFFORT_MINIMAL\x10\x01\x12\x18\n\x14REASONING_EFFORT_LOW\x10\x02\x12\x1b\n\x17REASONING_EFFORT_MEDIUM\x10\x03\x12\x19\n\x15REASONING_EFFORT_HIGH\x10\x04\"c\n\tVerbosity\x12\x19\n\x15VERBOSITY_UNSPECIFIED\x10\x00\x12\x11\n\rVERBOSITY_LOW\x10\x01\x12\x14\n\x10VERBOSITY_MEDIUM\x10\x02\x12\x12\n\x0eVERBOSITY_HIGH\x10\x03\x42\x14\n\x12_frequency_penaltyB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x04\n\x02_nB\x13\n\x11_presence_penaltyB\x07\n\x05_stopB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\x0b\n\t_base_urlB\x0e\n\x0c_api_versionB\x10\n\x0e_resource_nameB\x10\n\x0e_deployment_idB\x0b\n\t_is_azureB\t\n\x07_imagesB\x13\n\x11_image_propertiesB\x13\n\x11_reasoning_effortB\x0c\n\n_verbosity\"\x92\x05\n\x10GenerativeGoogle\x12\x1e\n\x11\x66requency_penalty\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x18\n\x0btemperature\x18\x05 \x01(\x01H\x04\x88\x01\x01\x12\x12\n\x05top_k\x18\x06 \x01(\x03H\x05\x88\x01\x01\x12\x12\n\x05top_p\x18\x07 \x01(\x01H\x06\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x08 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x19\n\x0c\x61pi_endpoint\x18\t \x01(\tH\x08\x88\x01\x01\x12\x17\n\nproject_id\x18\n \x01(\tH\t\x88\x01\x01\x12\x18\n\x0b\x65ndpoint_id\x18\x0b \x01(\tH\n\x88\x01\x01\x12\x13\n\x06region\x18\x0c \x01(\tH\x0b\x88\x01\x01\x12+\n\x06images\x18\r \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x0c\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0e \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\r\x88\x01\x01\x42\x14\n\x12_frequency_penaltyB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x13\n\x11_presence_penaltyB\x0e\n\x0c_temperatureB\x08\n\x06_top_kB\x08\n\x06_top_pB\x11\n\x0f_stop_sequencesB\x0f\n\r_api_endpointB\r\n\x0b_project_idB\x0e\n\x0c_endpoint_idB\t\n\x07_regionB\t\n\x07_imagesB\x13\n\x11_image_properties\"\xd0\x03\n\x14GenerativeDatabricks\x12\x15\n\x08\x65ndpoint\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x1e\n\x11\x66requency_penalty\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x16\n\tlog_probs\x18\x04 \x01(\x08H\x03\x88\x01\x01\x12\x1a\n\rtop_log_probs\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x06 \x01(\x03H\x05\x88\x01\x01\x12\x0e\n\x01n\x18\x07 \x01(\x03H\x06\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x08 \x01(\x01H\x07\x88\x01\x01\x12)\n\x04stop\x18\t \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x08\x88\x01\x01\x12\x18\n\x0btemperature\x18\n \x01(\x01H\t\x88\x01\x01\x12\x12\n\x05top_p\x18\x0b \x01(\x01H\n\x88\x01\x01\x42\x0b\n\t_endpointB\x08\n\x06_modelB\x14\n\x12_frequency_penaltyB\x0c\n\n_log_probsB\x10\n\x0e_top_log_probsB\r\n\x0b_max_tokensB\x04\n\x02_nB\x13\n\x11_presence_penaltyB\x07\n\x05_stopB\x0e\n\x0c_temperatureB\x08\n\x06_top_p\"\xde\x01\n\x14GenerativeFriendliAI\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x12\x18\n\x0btemperature\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x0e\n\x01n\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x12\n\x05top_p\x18\x06 \x01(\x01H\x05\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\r\n\x0b_max_tokensB\x0e\n\x0c_temperatureB\x04\n\x02_nB\x08\n\x06_top_p\"\xc4\x01\n\x10GenerativeNvidia\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x12\n\x05top_p\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x05 \x01(\x03H\x04\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\r\n\x0b_max_tokens\"\xc5\x02\n\rGenerativeXAI\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x12\n\x05top_p\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12+\n\x06images\x18\x06 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x05\x88\x01\x01\x12\x35\n\x10image_properties\x18\x07 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x06\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\r\n\x0b_max_tokensB\t\n\x07_imagesB\x13\n\x11_image_properties\"\xce\x02\n\x16GenerativeContextualAI\x12\x12\n\x05model\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x18\n\x0btemperature\x18\x02 \x01(\x01H\x01\x88\x01\x01\x12\x12\n\x05top_p\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x1b\n\x0emax_new_tokens\x18\x04 \x01(\x03H\x03\x88\x01\x01\x12\x1a\n\rsystem_prompt\x18\x05 \x01(\tH\x04\x88\x01\x01\x12\x1d\n\x10\x61void_commentary\x18\x06 \x01(\x08H\x05\x88\x01\x01\x12.\n\tknowledge\x18\x07 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x06\x88\x01\x01\x42\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\x11\n\x0f_max_new_tokensB\x10\n\x0e_system_promptB\x13\n\x11_avoid_commentaryB\x0c\n\n_knowledge\"\x92\x01\n\x1bGenerativeAnthropicMetadata\x12=\n\x05usage\x18\x01 \x01(\x0b\x32..weaviate.v1.GenerativeAnthropicMetadata.Usage\x1a\x34\n\x05Usage\x12\x14\n\x0cinput_tokens\x18\x01 \x01(\x03\x12\x15\n\routput_tokens\x18\x02 \x01(\x03\"\x1c\n\x1aGenerativeAnyscaleMetadata\"\x17\n\x15GenerativeAWSMetadata\"\x9c\x06\n\x18GenerativeCohereMetadata\x12J\n\x0b\x61pi_version\x18\x01 \x01(\x0b\x32\x30.weaviate.v1.GenerativeCohereMetadata.ApiVersionH\x00\x88\x01\x01\x12L\n\x0c\x62illed_units\x18\x02 \x01(\x0b\x32\x31.weaviate.v1.GenerativeCohereMetadata.BilledUnitsH\x01\x88\x01\x01\x12\x41\n\x06tokens\x18\x03 \x01(\x0b\x32,.weaviate.v1.GenerativeCohereMetadata.TokensH\x02\x88\x01\x01\x12-\n\x08warnings\x18\x04 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x03\x88\x01\x01\x1a\x8e\x01\n\nApiVersion\x12\x14\n\x07version\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x1a\n\ris_deprecated\x18\x02 \x01(\x08H\x01\x88\x01\x01\x12\x1c\n\x0fis_experimental\x18\x03 \x01(\x08H\x02\x88\x01\x01\x42\n\n\x08_versionB\x10\n\x0e_is_deprecatedB\x12\n\x10_is_experimental\x1a\xc5\x01\n\x0b\x42illedUnits\x12\x19\n\x0cinput_tokens\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x1a\n\routput_tokens\x18\x02 \x01(\x01H\x01\x88\x01\x01\x12\x19\n\x0csearch_units\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x1c\n\x0f\x63lassifications\x18\x04 \x01(\x01H\x03\x88\x01\x01\x42\x0f\n\r_input_tokensB\x10\n\x0e_output_tokensB\x0f\n\r_search_unitsB\x12\n\x10_classifications\x1a\x62\n\x06Tokens\x12\x19\n\x0cinput_tokens\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x1a\n\routput_tokens\x18\x02 \x01(\x01H\x01\x88\x01\x01\x42\x0f\n\r_input_tokensB\x10\n\x0e_output_tokensB\x0e\n\x0c_api_versionB\x0f\n\r_billed_unitsB\t\n\x07_tokensB\x0b\n\t_warnings\"\x19\n\x17GenerativeDummyMetadata\"\x81\x02\n\x19GenerativeMistralMetadata\x12@\n\x05usage\x18\x01 \x01(\x0b\x32,.weaviate.v1.GenerativeMistralMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\x1a\n\x18GenerativeOllamaMetadata\"\xff\x01\n\x18GenerativeOpenAIMetadata\x12?\n\x05usage\x18\x01 \x01(\x0b\x32+.weaviate.v1.GenerativeOpenAIMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\xe8\x06\n\x18GenerativeGoogleMetadata\x12\x45\n\x08metadata\x18\x01 \x01(\x0b\x32..weaviate.v1.GenerativeGoogleMetadata.MetadataH\x00\x88\x01\x01\x12P\n\x0eusage_metadata\x18\x02 \x01(\x0b\x32\x33.weaviate.v1.GenerativeGoogleMetadata.UsageMetadataH\x01\x88\x01\x01\x1a~\n\nTokenCount\x12&\n\x19total_billable_characters\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x42\x1c\n\x1a_total_billable_charactersB\x0f\n\r_total_tokens\x1a\xe1\x01\n\rTokenMetadata\x12P\n\x11input_token_count\x18\x01 \x01(\x0b\x32\x30.weaviate.v1.GenerativeGoogleMetadata.TokenCountH\x00\x88\x01\x01\x12Q\n\x12output_token_count\x18\x02 \x01(\x0b\x32\x30.weaviate.v1.GenerativeGoogleMetadata.TokenCountH\x01\x88\x01\x01\x42\x14\n\x12_input_token_countB\x15\n\x13_output_token_count\x1ao\n\x08Metadata\x12P\n\x0etoken_metadata\x18\x01 \x01(\x0b\x32\x33.weaviate.v1.GenerativeGoogleMetadata.TokenMetadataH\x00\x88\x01\x01\x42\x11\n\x0f_token_metadata\x1a\xbd\x01\n\rUsageMetadata\x12\x1f\n\x12prompt_token_count\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12#\n\x16\x63\x61ndidates_token_count\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x1e\n\x11total_token_count\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x15\n\x13_prompt_token_countB\x19\n\x17_candidates_token_countB\x14\n\x12_total_token_countB\x0b\n\t_metadataB\x11\n\x0f_usage_metadata\"\x87\x02\n\x1cGenerativeDatabricksMetadata\x12\x43\n\x05usage\x18\x01 \x01(\x0b\x32/.weaviate.v1.GenerativeDatabricksMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\x87\x02\n\x1cGenerativeFriendliAIMetadata\x12\x43\n\x05usage\x18\x01 \x01(\x0b\x32/.weaviate.v1.GenerativeFriendliAIMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\xff\x01\n\x18GenerativeNvidiaMetadata\x12?\n\x05usage\x18\x01 \x01(\x0b\x32+.weaviate.v1.GenerativeNvidiaMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\xf9\x01\n\x15GenerativeXAIMetadata\x12<\n\x05usage\x18\x01 \x01(\x0b\x32(.weaviate.v1.GenerativeXAIMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\x8f\x06\n\x12GenerativeMetadata\x12=\n\tanthropic\x18\x01 \x01(\x0b\x32(.weaviate.v1.GenerativeAnthropicMetadataH\x00\x12;\n\x08\x61nyscale\x18\x02 \x01(\x0b\x32\'.weaviate.v1.GenerativeAnyscaleMetadataH\x00\x12\x31\n\x03\x61ws\x18\x03 \x01(\x0b\x32\".weaviate.v1.GenerativeAWSMetadataH\x00\x12\x37\n\x06\x63ohere\x18\x04 \x01(\x0b\x32%.weaviate.v1.GenerativeCohereMetadataH\x00\x12\x35\n\x05\x64ummy\x18\x05 \x01(\x0b\x32$.weaviate.v1.GenerativeDummyMetadataH\x00\x12\x39\n\x07mistral\x18\x06 \x01(\x0b\x32&.weaviate.v1.GenerativeMistralMetadataH\x00\x12\x37\n\x06ollama\x18\x07 \x01(\x0b\x32%.weaviate.v1.GenerativeOllamaMetadataH\x00\x12\x37\n\x06openai\x18\x08 \x01(\x0b\x32%.weaviate.v1.GenerativeOpenAIMetadataH\x00\x12\x37\n\x06google\x18\t \x01(\x0b\x32%.weaviate.v1.GenerativeGoogleMetadataH\x00\x12?\n\ndatabricks\x18\n \x01(\x0b\x32).weaviate.v1.GenerativeDatabricksMetadataH\x00\x12?\n\nfriendliai\x18\x0b \x01(\x0b\x32).weaviate.v1.GenerativeFriendliAIMetadataH\x00\x12\x37\n\x06nvidia\x18\x0c \x01(\x0b\x32%.weaviate.v1.GenerativeNvidiaMetadataH\x00\x12\x31\n\x03xai\x18\r \x01(\x0b\x32\".weaviate.v1.GenerativeXAIMetadataH\x00\x42\x06\n\x04kind\"\xa2\x01\n\x0fGenerativeReply\x12\x0e\n\x06result\x18\x01 \x01(\t\x12\x30\n\x05\x64\x65\x62ug\x18\x02 \x01(\x0b\x32\x1c.weaviate.v1.GenerativeDebugH\x00\x88\x01\x01\x12\x36\n\x08metadata\x18\x03 \x01(\x0b\x32\x1f.weaviate.v1.GenerativeMetadataH\x01\x88\x01\x01\x42\x08\n\x06_debugB\x0b\n\t_metadata\"@\n\x10GenerativeResult\x12,\n\x06values\x18\x01 \x03(\x0b\x32\x1c.weaviate.v1.GenerativeReply\";\n\x0fGenerativeDebug\x12\x18\n\x0b\x66ull_prompt\x18\x01 \x01(\tH\x00\x88\x01\x01\x42\x0e\n\x0c_full_promptBt\n#io.weaviate.client.grpc.protocol.v1B\x17WeaviateProtoGenerativeZ4github.com/weaviate/weaviate/grpc/generated;protocolb\x06proto3') +DESCRIPTOR = _descriptor_pool.Default().AddSerializedFile(b'\n\x13v1/generative.proto\x12\x0bweaviate.v1\x1a\rv1/base.proto\"\xdd\x03\n\x10GenerativeSearch\x12\"\n\x16single_response_prompt\x18\x01 \x01(\tB\x02\x18\x01\x12!\n\x15grouped_response_task\x18\x02 \x01(\tB\x02\x18\x01\x12\x1e\n\x12grouped_properties\x18\x03 \x03(\tB\x02\x18\x01\x12\x34\n\x06single\x18\x04 \x01(\x0b\x32$.weaviate.v1.GenerativeSearch.Single\x12\x36\n\x07grouped\x18\x05 \x01(\x0b\x32%.weaviate.v1.GenerativeSearch.Grouped\x1aY\n\x06Single\x12\x0e\n\x06prompt\x18\x01 \x01(\t\x12\r\n\x05\x64\x65\x62ug\x18\x02 \x01(\x08\x12\x30\n\x07queries\x18\x03 \x03(\x0b\x32\x1f.weaviate.v1.GenerativeProvider\x1a\x98\x01\n\x07Grouped\x12\x0c\n\x04task\x18\x01 \x01(\t\x12/\n\nproperties\x18\x02 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x00\x88\x01\x01\x12\x30\n\x07queries\x18\x03 \x03(\x0b\x32\x1f.weaviate.v1.GenerativeProvider\x12\r\n\x05\x64\x65\x62ug\x18\x04 \x01(\x08\x42\r\n\x0b_properties\"\xfd\x05\n\x12GenerativeProvider\x12\x17\n\x0freturn_metadata\x18\x01 \x01(\x08\x12\x35\n\tanthropic\x18\x02 \x01(\x0b\x32 .weaviate.v1.GenerativeAnthropicH\x00\x12\x33\n\x08\x61nyscale\x18\x03 \x01(\x0b\x32\x1f.weaviate.v1.GenerativeAnyscaleH\x00\x12)\n\x03\x61ws\x18\x04 \x01(\x0b\x32\x1a.weaviate.v1.GenerativeAWSH\x00\x12/\n\x06\x63ohere\x18\x05 \x01(\x0b\x32\x1d.weaviate.v1.GenerativeCohereH\x00\x12-\n\x05\x64ummy\x18\x06 \x01(\x0b\x32\x1c.weaviate.v1.GenerativeDummyH\x00\x12\x31\n\x07mistral\x18\x07 \x01(\x0b\x32\x1e.weaviate.v1.GenerativeMistralH\x00\x12/\n\x06ollama\x18\x08 \x01(\x0b\x32\x1d.weaviate.v1.GenerativeOllamaH\x00\x12/\n\x06openai\x18\t \x01(\x0b\x32\x1d.weaviate.v1.GenerativeOpenAIH\x00\x12/\n\x06google\x18\n \x01(\x0b\x32\x1d.weaviate.v1.GenerativeGoogleH\x00\x12\x37\n\ndatabricks\x18\x0b \x01(\x0b\x32!.weaviate.v1.GenerativeDatabricksH\x00\x12\x37\n\nfriendliai\x18\x0c \x01(\x0b\x32!.weaviate.v1.GenerativeFriendliAIH\x00\x12/\n\x06nvidia\x18\r \x01(\x0b\x32\x1d.weaviate.v1.GenerativeNvidiaH\x00\x12)\n\x03xai\x18\x0e \x01(\x0b\x32\x1a.weaviate.v1.GenerativeXAIH\x00\x12;\n\x0c\x63ontextualai\x18\x0f \x01(\x0b\x32#.weaviate.v1.GenerativeContextualAIH\x00\x42\x06\n\x04kind\"\xb1\x03\n\x13GenerativeAnthropic\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x18\n\x0btemperature\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x12\n\x05top_k\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x12\n\x05top_p\x18\x06 \x01(\x01H\x05\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x07 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x06\x88\x01\x01\x12+\n\x06images\x18\x08 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x35\n\x10image_properties\x18\t \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x08\x88\x01\x01\x42\x0b\n\t_base_urlB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_kB\x08\n\x06_top_pB\x11\n\x0f_stop_sequencesB\t\n\x07_imagesB\x13\n\x11_image_properties\"\x80\x01\n\x12GenerativeAnyscale\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\x0e\n\x0c_temperature\"\x8d\x04\n\rGenerativeAWS\x12\x12\n\x05model\x18\x03 \x01(\tH\x00\x88\x01\x01\x12\x18\n\x0btemperature\x18\x08 \x01(\x01H\x01\x88\x01\x01\x12\x14\n\x07service\x18\t \x01(\tH\x02\x88\x01\x01\x12\x13\n\x06region\x18\n \x01(\tH\x03\x88\x01\x01\x12\x15\n\x08\x65ndpoint\x18\x0b \x01(\tH\x04\x88\x01\x01\x12\x19\n\x0ctarget_model\x18\x0c \x01(\tH\x05\x88\x01\x01\x12\x1b\n\x0etarget_variant\x18\r \x01(\tH\x06\x88\x01\x01\x12+\n\x06images\x18\x0e \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0f \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x08\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x10 \x01(\x03H\t\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x11 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\n\x88\x01\x01\x42\x08\n\x06_modelB\x0e\n\x0c_temperatureB\n\n\x08_serviceB\t\n\x07_regionB\x0b\n\t_endpointB\x0f\n\r_target_modelB\x11\n\x0f_target_variantB\t\n\x07_imagesB\x13\n\x11_image_propertiesB\r\n\x0b_max_tokensB\x11\n\x0f_stop_sequences\"\x88\x04\n\x10GenerativeCohere\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x1e\n\x11\x66requency_penalty\x18\x02 \x01(\x01H\x01\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x12\x12\n\x05model\x18\x04 \x01(\tH\x03\x88\x01\x01\x12\x0e\n\x01k\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x0e\n\x01p\x18\x06 \x01(\x01H\x05\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x07 \x01(\x01H\x06\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x08 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x18\n\x0btemperature\x18\t \x01(\x01H\x08\x88\x01\x01\x12+\n\x06images\x18\n \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\t\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0b \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\n\x88\x01\x01\x42\x0b\n\t_base_urlB\x14\n\x12_frequency_penaltyB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x04\n\x02_kB\x04\n\x02_pB\x13\n\x11_presence_penaltyB\x11\n\x0f_stop_sequencesB\x0e\n\x0c_temperatureB\t\n\x07_imagesB\x13\n\x11_image_properties\"\x11\n\x0fGenerativeDummy\"\xc5\x01\n\x11GenerativeMistral\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x18\n\x0btemperature\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x12\n\x05top_p\x18\x05 \x01(\x01H\x04\x88\x01\x01\x42\x0b\n\t_base_urlB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_p\"\x8a\x02\n\x10GenerativeOllama\x12\x19\n\x0c\x61pi_endpoint\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12+\n\x06images\x18\x04 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x03\x88\x01\x01\x12\x35\n\x10image_properties\x18\x05 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x04\x88\x01\x01\x42\x0f\n\r_api_endpointB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\t\n\x07_imagesB\x13\n\x11_image_properties\"\xe3\x08\n\x10GenerativeOpenAI\x12\x1e\n\x11\x66requency_penalty\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x0e\n\x01n\x18\x04 \x01(\x03H\x03\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x05 \x01(\x01H\x04\x88\x01\x01\x12)\n\x04stop\x18\x06 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x05\x88\x01\x01\x12\x18\n\x0btemperature\x18\x07 \x01(\x01H\x06\x88\x01\x01\x12\x12\n\x05top_p\x18\x08 \x01(\x01H\x07\x88\x01\x01\x12\x15\n\x08\x62\x61se_url\x18\t \x01(\tH\x08\x88\x01\x01\x12\x18\n\x0b\x61pi_version\x18\n \x01(\tH\t\x88\x01\x01\x12\x1a\n\rresource_name\x18\x0b \x01(\tH\n\x88\x01\x01\x12\x1a\n\rdeployment_id\x18\x0c \x01(\tH\x0b\x88\x01\x01\x12\x15\n\x08is_azure\x18\r \x01(\x08H\x0c\x88\x01\x01\x12+\n\x06images\x18\x0e \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\r\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0f \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x0e\x88\x01\x01\x12L\n\x10reasoning_effort\x18\x10 \x01(\x0e\x32-.weaviate.v1.GenerativeOpenAI.ReasoningEffortH\x0f\x88\x01\x01\x12?\n\tverbosity\x18\x11 \x01(\x0e\x32\'.weaviate.v1.GenerativeOpenAI.VerbosityH\x10\x88\x01\x01\"\xa3\x01\n\x0fReasoningEffort\x12 \n\x1cREASONING_EFFORT_UNSPECIFIED\x10\x00\x12\x1c\n\x18REASONING_EFFORT_MINIMAL\x10\x01\x12\x18\n\x14REASONING_EFFORT_LOW\x10\x02\x12\x1b\n\x17REASONING_EFFORT_MEDIUM\x10\x03\x12\x19\n\x15REASONING_EFFORT_HIGH\x10\x04\"c\n\tVerbosity\x12\x19\n\x15VERBOSITY_UNSPECIFIED\x10\x00\x12\x11\n\rVERBOSITY_LOW\x10\x01\x12\x14\n\x10VERBOSITY_MEDIUM\x10\x02\x12\x12\n\x0eVERBOSITY_HIGH\x10\x03\x42\x14\n\x12_frequency_penaltyB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x04\n\x02_nB\x13\n\x11_presence_penaltyB\x07\n\x05_stopB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\x0b\n\t_base_urlB\x0e\n\x0c_api_versionB\x10\n\x0e_resource_nameB\x10\n\x0e_deployment_idB\x0b\n\t_is_azureB\t\n\x07_imagesB\x13\n\x11_image_propertiesB\x13\n\x11_reasoning_effortB\x0c\n\n_verbosity\"\x92\x05\n\x10GenerativeGoogle\x12\x1e\n\x11\x66requency_penalty\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x12\n\x05model\x18\x03 \x01(\tH\x02\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x18\n\x0btemperature\x18\x05 \x01(\x01H\x04\x88\x01\x01\x12\x12\n\x05top_k\x18\x06 \x01(\x03H\x05\x88\x01\x01\x12\x12\n\x05top_p\x18\x07 \x01(\x01H\x06\x88\x01\x01\x12\x33\n\x0estop_sequences\x18\x08 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x07\x88\x01\x01\x12\x19\n\x0c\x61pi_endpoint\x18\t \x01(\tH\x08\x88\x01\x01\x12\x17\n\nproject_id\x18\n \x01(\tH\t\x88\x01\x01\x12\x18\n\x0b\x65ndpoint_id\x18\x0b \x01(\tH\n\x88\x01\x01\x12\x13\n\x06region\x18\x0c \x01(\tH\x0b\x88\x01\x01\x12+\n\x06images\x18\r \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x0c\x88\x01\x01\x12\x35\n\x10image_properties\x18\x0e \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\r\x88\x01\x01\x42\x14\n\x12_frequency_penaltyB\r\n\x0b_max_tokensB\x08\n\x06_modelB\x13\n\x11_presence_penaltyB\x0e\n\x0c_temperatureB\x08\n\x06_top_kB\x08\n\x06_top_pB\x11\n\x0f_stop_sequencesB\x0f\n\r_api_endpointB\r\n\x0b_project_idB\x0e\n\x0c_endpoint_idB\t\n\x07_regionB\t\n\x07_imagesB\x13\n\x11_image_properties\"\xd0\x03\n\x14GenerativeDatabricks\x12\x15\n\x08\x65ndpoint\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x1e\n\x11\x66requency_penalty\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x16\n\tlog_probs\x18\x04 \x01(\x08H\x03\x88\x01\x01\x12\x1a\n\rtop_log_probs\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x06 \x01(\x03H\x05\x88\x01\x01\x12\x0e\n\x01n\x18\x07 \x01(\x03H\x06\x88\x01\x01\x12\x1d\n\x10presence_penalty\x18\x08 \x01(\x01H\x07\x88\x01\x01\x12)\n\x04stop\x18\t \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x08\x88\x01\x01\x12\x18\n\x0btemperature\x18\n \x01(\x01H\t\x88\x01\x01\x12\x12\n\x05top_p\x18\x0b \x01(\x01H\n\x88\x01\x01\x42\x0b\n\t_endpointB\x08\n\x06_modelB\x14\n\x12_frequency_penaltyB\x0c\n\n_log_probsB\x10\n\x0e_top_log_probsB\r\n\x0b_max_tokensB\x04\n\x02_nB\x13\n\x11_presence_penaltyB\x07\n\x05_stopB\x0e\n\x0c_temperatureB\x08\n\x06_top_p\"\xde\x01\n\x14GenerativeFriendliAI\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x12\x18\n\x0btemperature\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x0e\n\x01n\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12\x12\n\x05top_p\x18\x06 \x01(\x01H\x05\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\r\n\x0b_max_tokensB\x0e\n\x0c_temperatureB\x04\n\x02_nB\x08\n\x06_top_p\"\xc4\x01\n\x10GenerativeNvidia\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x12\n\x05top_p\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x05 \x01(\x03H\x04\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\r\n\x0b_max_tokens\"\xc5\x02\n\rGenerativeXAI\x12\x15\n\x08\x62\x61se_url\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x12\n\x05model\x18\x02 \x01(\tH\x01\x88\x01\x01\x12\x18\n\x0btemperature\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x12\n\x05top_p\x18\x04 \x01(\x01H\x03\x88\x01\x01\x12\x17\n\nmax_tokens\x18\x05 \x01(\x03H\x04\x88\x01\x01\x12+\n\x06images\x18\x06 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x05\x88\x01\x01\x12\x35\n\x10image_properties\x18\x07 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x06\x88\x01\x01\x42\x0b\n\t_base_urlB\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\r\n\x0b_max_tokensB\t\n\x07_imagesB\x13\n\x11_image_properties\"\xce\x02\n\x16GenerativeContextualAI\x12\x12\n\x05model\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x18\n\x0btemperature\x18\x02 \x01(\x01H\x01\x88\x01\x01\x12\x12\n\x05top_p\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x1b\n\x0emax_new_tokens\x18\x04 \x01(\x03H\x03\x88\x01\x01\x12\x1a\n\rsystem_prompt\x18\x05 \x01(\tH\x04\x88\x01\x01\x12\x1d\n\x10\x61void_commentary\x18\x06 \x01(\x08H\x05\x88\x01\x01\x12.\n\tknowledge\x18\x07 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x06\x88\x01\x01\x42\x08\n\x06_modelB\x0e\n\x0c_temperatureB\x08\n\x06_top_pB\x11\n\x0f_max_new_tokensB\x10\n\x0e_system_promptB\x13\n\x11_avoid_commentaryB\x0c\n\n_knowledge\"\x92\x01\n\x1bGenerativeAnthropicMetadata\x12=\n\x05usage\x18\x01 \x01(\x0b\x32..weaviate.v1.GenerativeAnthropicMetadata.Usage\x1a\x34\n\x05Usage\x12\x14\n\x0cinput_tokens\x18\x01 \x01(\x03\x12\x15\n\routput_tokens\x18\x02 \x01(\x03\"\x1c\n\x1aGenerativeAnyscaleMetadata\"\x17\n\x15GenerativeAWSMetadata\"\x9c\x06\n\x18GenerativeCohereMetadata\x12J\n\x0b\x61pi_version\x18\x01 \x01(\x0b\x32\x30.weaviate.v1.GenerativeCohereMetadata.ApiVersionH\x00\x88\x01\x01\x12L\n\x0c\x62illed_units\x18\x02 \x01(\x0b\x32\x31.weaviate.v1.GenerativeCohereMetadata.BilledUnitsH\x01\x88\x01\x01\x12\x41\n\x06tokens\x18\x03 \x01(\x0b\x32,.weaviate.v1.GenerativeCohereMetadata.TokensH\x02\x88\x01\x01\x12-\n\x08warnings\x18\x04 \x01(\x0b\x32\x16.weaviate.v1.TextArrayH\x03\x88\x01\x01\x1a\x8e\x01\n\nApiVersion\x12\x14\n\x07version\x18\x01 \x01(\tH\x00\x88\x01\x01\x12\x1a\n\ris_deprecated\x18\x02 \x01(\x08H\x01\x88\x01\x01\x12\x1c\n\x0fis_experimental\x18\x03 \x01(\x08H\x02\x88\x01\x01\x42\n\n\x08_versionB\x10\n\x0e_is_deprecatedB\x12\n\x10_is_experimental\x1a\xc5\x01\n\x0b\x42illedUnits\x12\x19\n\x0cinput_tokens\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x1a\n\routput_tokens\x18\x02 \x01(\x01H\x01\x88\x01\x01\x12\x19\n\x0csearch_units\x18\x03 \x01(\x01H\x02\x88\x01\x01\x12\x1c\n\x0f\x63lassifications\x18\x04 \x01(\x01H\x03\x88\x01\x01\x42\x0f\n\r_input_tokensB\x10\n\x0e_output_tokensB\x0f\n\r_search_unitsB\x12\n\x10_classifications\x1a\x62\n\x06Tokens\x12\x19\n\x0cinput_tokens\x18\x01 \x01(\x01H\x00\x88\x01\x01\x12\x1a\n\routput_tokens\x18\x02 \x01(\x01H\x01\x88\x01\x01\x42\x0f\n\r_input_tokensB\x10\n\x0e_output_tokensB\x0e\n\x0c_api_versionB\x0f\n\r_billed_unitsB\t\n\x07_tokensB\x0b\n\t_warnings\"\x19\n\x17GenerativeDummyMetadata\"\x81\x02\n\x19GenerativeMistralMetadata\x12@\n\x05usage\x18\x01 \x01(\x0b\x32,.weaviate.v1.GenerativeMistralMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\x1a\n\x18GenerativeOllamaMetadata\"\xff\x01\n\x18GenerativeOpenAIMetadata\x12?\n\x05usage\x18\x01 \x01(\x0b\x32+.weaviate.v1.GenerativeOpenAIMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\xe8\x06\n\x18GenerativeGoogleMetadata\x12\x45\n\x08metadata\x18\x01 \x01(\x0b\x32..weaviate.v1.GenerativeGoogleMetadata.MetadataH\x00\x88\x01\x01\x12P\n\x0eusage_metadata\x18\x02 \x01(\x0b\x32\x33.weaviate.v1.GenerativeGoogleMetadata.UsageMetadataH\x01\x88\x01\x01\x1a~\n\nTokenCount\x12&\n\x19total_billable_characters\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x42\x1c\n\x1a_total_billable_charactersB\x0f\n\r_total_tokens\x1a\xe1\x01\n\rTokenMetadata\x12P\n\x11input_token_count\x18\x01 \x01(\x0b\x32\x30.weaviate.v1.GenerativeGoogleMetadata.TokenCountH\x00\x88\x01\x01\x12Q\n\x12output_token_count\x18\x02 \x01(\x0b\x32\x30.weaviate.v1.GenerativeGoogleMetadata.TokenCountH\x01\x88\x01\x01\x42\x14\n\x12_input_token_countB\x15\n\x13_output_token_count\x1ao\n\x08Metadata\x12P\n\x0etoken_metadata\x18\x01 \x01(\x0b\x32\x33.weaviate.v1.GenerativeGoogleMetadata.TokenMetadataH\x00\x88\x01\x01\x42\x11\n\x0f_token_metadata\x1a\xbd\x01\n\rUsageMetadata\x12\x1f\n\x12prompt_token_count\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12#\n\x16\x63\x61ndidates_token_count\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x1e\n\x11total_token_count\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x15\n\x13_prompt_token_countB\x19\n\x17_candidates_token_countB\x14\n\x12_total_token_countB\x0b\n\t_metadataB\x11\n\x0f_usage_metadata\"\x87\x02\n\x1cGenerativeDatabricksMetadata\x12\x43\n\x05usage\x18\x01 \x01(\x0b\x32/.weaviate.v1.GenerativeDatabricksMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\x87\x02\n\x1cGenerativeFriendliAIMetadata\x12\x43\n\x05usage\x18\x01 \x01(\x0b\x32/.weaviate.v1.GenerativeFriendliAIMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\xff\x01\n\x18GenerativeNvidiaMetadata\x12?\n\x05usage\x18\x01 \x01(\x0b\x32+.weaviate.v1.GenerativeNvidiaMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\xf9\x01\n\x15GenerativeXAIMetadata\x12<\n\x05usage\x18\x01 \x01(\x0b\x32(.weaviate.v1.GenerativeXAIMetadata.UsageH\x00\x88\x01\x01\x1a\x97\x01\n\x05Usage\x12\x1a\n\rprompt_tokens\x18\x01 \x01(\x03H\x00\x88\x01\x01\x12\x1e\n\x11\x63ompletion_tokens\x18\x02 \x01(\x03H\x01\x88\x01\x01\x12\x19\n\x0ctotal_tokens\x18\x03 \x01(\x03H\x02\x88\x01\x01\x42\x10\n\x0e_prompt_tokensB\x14\n\x12_completion_tokensB\x0f\n\r_total_tokensB\x08\n\x06_usage\"\x8f\x06\n\x12GenerativeMetadata\x12=\n\tanthropic\x18\x01 \x01(\x0b\x32(.weaviate.v1.GenerativeAnthropicMetadataH\x00\x12;\n\x08\x61nyscale\x18\x02 \x01(\x0b\x32\'.weaviate.v1.GenerativeAnyscaleMetadataH\x00\x12\x31\n\x03\x61ws\x18\x03 \x01(\x0b\x32\".weaviate.v1.GenerativeAWSMetadataH\x00\x12\x37\n\x06\x63ohere\x18\x04 \x01(\x0b\x32%.weaviate.v1.GenerativeCohereMetadataH\x00\x12\x35\n\x05\x64ummy\x18\x05 \x01(\x0b\x32$.weaviate.v1.GenerativeDummyMetadataH\x00\x12\x39\n\x07mistral\x18\x06 \x01(\x0b\x32&.weaviate.v1.GenerativeMistralMetadataH\x00\x12\x37\n\x06ollama\x18\x07 \x01(\x0b\x32%.weaviate.v1.GenerativeOllamaMetadataH\x00\x12\x37\n\x06openai\x18\x08 \x01(\x0b\x32%.weaviate.v1.GenerativeOpenAIMetadataH\x00\x12\x37\n\x06google\x18\t \x01(\x0b\x32%.weaviate.v1.GenerativeGoogleMetadataH\x00\x12?\n\ndatabricks\x18\n \x01(\x0b\x32).weaviate.v1.GenerativeDatabricksMetadataH\x00\x12?\n\nfriendliai\x18\x0b \x01(\x0b\x32).weaviate.v1.GenerativeFriendliAIMetadataH\x00\x12\x37\n\x06nvidia\x18\x0c \x01(\x0b\x32%.weaviate.v1.GenerativeNvidiaMetadataH\x00\x12\x31\n\x03xai\x18\r \x01(\x0b\x32\".weaviate.v1.GenerativeXAIMetadataH\x00\x42\x06\n\x04kind\"\xa2\x01\n\x0fGenerativeReply\x12\x0e\n\x06result\x18\x01 \x01(\t\x12\x30\n\x05\x64\x65\x62ug\x18\x02 \x01(\x0b\x32\x1c.weaviate.v1.GenerativeDebugH\x00\x88\x01\x01\x12\x36\n\x08metadata\x18\x03 \x01(\x0b\x32\x1f.weaviate.v1.GenerativeMetadataH\x01\x88\x01\x01\x42\x08\n\x06_debugB\x0b\n\t_metadata\"@\n\x10GenerativeResult\x12,\n\x06values\x18\x01 \x03(\x0b\x32\x1c.weaviate.v1.GenerativeReply\";\n\x0fGenerativeDebug\x12\x18\n\x0b\x66ull_prompt\x18\x01 \x01(\tH\x00\x88\x01\x01\x42\x0e\n\x0c_full_promptBt\n#io.weaviate.client.grpc.protocol.v1B\x17WeaviateProtoGenerativeZ4github.com/weaviate/weaviate/grpc/generated;protocolb\x06proto3') _globals = globals() _builder.BuildMessageAndEnumDescriptors(DESCRIPTOR, _globals) @@ -52,93 +52,93 @@ _globals['_GENERATIVEANYSCALE']._serialized_start=1736 _globals['_GENERATIVEANYSCALE']._serialized_end=1864 _globals['_GENERATIVEAWS']._serialized_start=1867 - _globals['_GENERATIVEAWS']._serialized_end=2320 - _globals['_GENERATIVECOHERE']._serialized_start=2323 - _globals['_GENERATIVECOHERE']._serialized_end=2843 - _globals['_GENERATIVEDUMMY']._serialized_start=2845 - _globals['_GENERATIVEDUMMY']._serialized_end=2862 - _globals['_GENERATIVEMISTRAL']._serialized_start=2865 - _globals['_GENERATIVEMISTRAL']._serialized_end=3062 - _globals['_GENERATIVEOLLAMA']._serialized_start=3065 - _globals['_GENERATIVEOLLAMA']._serialized_end=3331 - _globals['_GENERATIVEOPENAI']._serialized_start=3334 - _globals['_GENERATIVEOPENAI']._serialized_end=4457 - _globals['_GENERATIVEOPENAI_REASONINGEFFORT']._serialized_start=3939 - _globals['_GENERATIVEOPENAI_REASONINGEFFORT']._serialized_end=4102 - _globals['_GENERATIVEOPENAI_VERBOSITY']._serialized_start=4104 - _globals['_GENERATIVEOPENAI_VERBOSITY']._serialized_end=4203 - _globals['_GENERATIVEGOOGLE']._serialized_start=4460 - _globals['_GENERATIVEGOOGLE']._serialized_end=5118 - _globals['_GENERATIVEDATABRICKS']._serialized_start=5121 - _globals['_GENERATIVEDATABRICKS']._serialized_end=5585 - _globals['_GENERATIVEFRIENDLIAI']._serialized_start=5588 - _globals['_GENERATIVEFRIENDLIAI']._serialized_end=5810 - _globals['_GENERATIVENVIDIA']._serialized_start=5813 - _globals['_GENERATIVENVIDIA']._serialized_end=6009 - _globals['_GENERATIVEXAI']._serialized_start=6012 - _globals['_GENERATIVEXAI']._serialized_end=6337 - _globals['_GENERATIVECONTEXTUALAI']._serialized_start=6340 - _globals['_GENERATIVECONTEXTUALAI']._serialized_end=6674 - _globals['_GENERATIVEANTHROPICMETADATA']._serialized_start=6677 - _globals['_GENERATIVEANTHROPICMETADATA']._serialized_end=6823 - _globals['_GENERATIVEANTHROPICMETADATA_USAGE']._serialized_start=6771 - _globals['_GENERATIVEANTHROPICMETADATA_USAGE']._serialized_end=6823 - _globals['_GENERATIVEANYSCALEMETADATA']._serialized_start=6825 - _globals['_GENERATIVEANYSCALEMETADATA']._serialized_end=6853 - _globals['_GENERATIVEAWSMETADATA']._serialized_start=6855 - _globals['_GENERATIVEAWSMETADATA']._serialized_end=6878 - _globals['_GENERATIVECOHEREMETADATA']._serialized_start=6881 - _globals['_GENERATIVECOHEREMETADATA']._serialized_end=7677 - _globals['_GENERATIVECOHEREMETADATA_APIVERSION']._serialized_start=7178 - _globals['_GENERATIVECOHEREMETADATA_APIVERSION']._serialized_end=7320 - _globals['_GENERATIVECOHEREMETADATA_BILLEDUNITS']._serialized_start=7323 - _globals['_GENERATIVECOHEREMETADATA_BILLEDUNITS']._serialized_end=7520 - _globals['_GENERATIVECOHEREMETADATA_TOKENS']._serialized_start=7522 - _globals['_GENERATIVECOHEREMETADATA_TOKENS']._serialized_end=7620 - _globals['_GENERATIVEDUMMYMETADATA']._serialized_start=7679 - _globals['_GENERATIVEDUMMYMETADATA']._serialized_end=7704 - _globals['_GENERATIVEMISTRALMETADATA']._serialized_start=7707 - _globals['_GENERATIVEMISTRALMETADATA']._serialized_end=7964 - _globals['_GENERATIVEMISTRALMETADATA_USAGE']._serialized_start=7803 - _globals['_GENERATIVEMISTRALMETADATA_USAGE']._serialized_end=7954 - _globals['_GENERATIVEOLLAMAMETADATA']._serialized_start=7966 - _globals['_GENERATIVEOLLAMAMETADATA']._serialized_end=7992 - _globals['_GENERATIVEOPENAIMETADATA']._serialized_start=7995 - _globals['_GENERATIVEOPENAIMETADATA']._serialized_end=8250 - _globals['_GENERATIVEOPENAIMETADATA_USAGE']._serialized_start=7803 - _globals['_GENERATIVEOPENAIMETADATA_USAGE']._serialized_end=7954 - _globals['_GENERATIVEGOOGLEMETADATA']._serialized_start=8253 - _globals['_GENERATIVEGOOGLEMETADATA']._serialized_end=9125 - _globals['_GENERATIVEGOOGLEMETADATA_TOKENCOUNT']._serialized_start=8434 - _globals['_GENERATIVEGOOGLEMETADATA_TOKENCOUNT']._serialized_end=8560 - _globals['_GENERATIVEGOOGLEMETADATA_TOKENMETADATA']._serialized_start=8563 - _globals['_GENERATIVEGOOGLEMETADATA_TOKENMETADATA']._serialized_end=8788 - _globals['_GENERATIVEGOOGLEMETADATA_METADATA']._serialized_start=8790 - _globals['_GENERATIVEGOOGLEMETADATA_METADATA']._serialized_end=8901 - _globals['_GENERATIVEGOOGLEMETADATA_USAGEMETADATA']._serialized_start=8904 - _globals['_GENERATIVEGOOGLEMETADATA_USAGEMETADATA']._serialized_end=9093 - _globals['_GENERATIVEDATABRICKSMETADATA']._serialized_start=9128 - _globals['_GENERATIVEDATABRICKSMETADATA']._serialized_end=9391 - _globals['_GENERATIVEDATABRICKSMETADATA_USAGE']._serialized_start=7803 - _globals['_GENERATIVEDATABRICKSMETADATA_USAGE']._serialized_end=7954 - _globals['_GENERATIVEFRIENDLIAIMETADATA']._serialized_start=9394 - _globals['_GENERATIVEFRIENDLIAIMETADATA']._serialized_end=9657 - _globals['_GENERATIVEFRIENDLIAIMETADATA_USAGE']._serialized_start=7803 - _globals['_GENERATIVEFRIENDLIAIMETADATA_USAGE']._serialized_end=7954 - _globals['_GENERATIVENVIDIAMETADATA']._serialized_start=9660 - _globals['_GENERATIVENVIDIAMETADATA']._serialized_end=9915 - _globals['_GENERATIVENVIDIAMETADATA_USAGE']._serialized_start=7803 - _globals['_GENERATIVENVIDIAMETADATA_USAGE']._serialized_end=7954 - _globals['_GENERATIVEXAIMETADATA']._serialized_start=9918 - _globals['_GENERATIVEXAIMETADATA']._serialized_end=10167 - _globals['_GENERATIVEXAIMETADATA_USAGE']._serialized_start=7803 - _globals['_GENERATIVEXAIMETADATA_USAGE']._serialized_end=7954 - _globals['_GENERATIVEMETADATA']._serialized_start=10170 - _globals['_GENERATIVEMETADATA']._serialized_end=10953 - _globals['_GENERATIVEREPLY']._serialized_start=10956 - _globals['_GENERATIVEREPLY']._serialized_end=11118 - _globals['_GENERATIVERESULT']._serialized_start=11120 - _globals['_GENERATIVERESULT']._serialized_end=11184 - _globals['_GENERATIVEDEBUG']._serialized_start=11186 - _globals['_GENERATIVEDEBUG']._serialized_end=11245 + _globals['_GENERATIVEAWS']._serialized_end=2392 + _globals['_GENERATIVECOHERE']._serialized_start=2395 + _globals['_GENERATIVECOHERE']._serialized_end=2915 + _globals['_GENERATIVEDUMMY']._serialized_start=2917 + _globals['_GENERATIVEDUMMY']._serialized_end=2934 + _globals['_GENERATIVEMISTRAL']._serialized_start=2937 + _globals['_GENERATIVEMISTRAL']._serialized_end=3134 + _globals['_GENERATIVEOLLAMA']._serialized_start=3137 + _globals['_GENERATIVEOLLAMA']._serialized_end=3403 + _globals['_GENERATIVEOPENAI']._serialized_start=3406 + _globals['_GENERATIVEOPENAI']._serialized_end=4529 + _globals['_GENERATIVEOPENAI_REASONINGEFFORT']._serialized_start=4011 + _globals['_GENERATIVEOPENAI_REASONINGEFFORT']._serialized_end=4174 + _globals['_GENERATIVEOPENAI_VERBOSITY']._serialized_start=4176 + _globals['_GENERATIVEOPENAI_VERBOSITY']._serialized_end=4275 + _globals['_GENERATIVEGOOGLE']._serialized_start=4532 + _globals['_GENERATIVEGOOGLE']._serialized_end=5190 + _globals['_GENERATIVEDATABRICKS']._serialized_start=5193 + _globals['_GENERATIVEDATABRICKS']._serialized_end=5657 + _globals['_GENERATIVEFRIENDLIAI']._serialized_start=5660 + _globals['_GENERATIVEFRIENDLIAI']._serialized_end=5882 + _globals['_GENERATIVENVIDIA']._serialized_start=5885 + _globals['_GENERATIVENVIDIA']._serialized_end=6081 + _globals['_GENERATIVEXAI']._serialized_start=6084 + _globals['_GENERATIVEXAI']._serialized_end=6409 + _globals['_GENERATIVECONTEXTUALAI']._serialized_start=6412 + _globals['_GENERATIVECONTEXTUALAI']._serialized_end=6746 + _globals['_GENERATIVEANTHROPICMETADATA']._serialized_start=6749 + _globals['_GENERATIVEANTHROPICMETADATA']._serialized_end=6895 + _globals['_GENERATIVEANTHROPICMETADATA_USAGE']._serialized_start=6843 + _globals['_GENERATIVEANTHROPICMETADATA_USAGE']._serialized_end=6895 + _globals['_GENERATIVEANYSCALEMETADATA']._serialized_start=6897 + _globals['_GENERATIVEANYSCALEMETADATA']._serialized_end=6925 + _globals['_GENERATIVEAWSMETADATA']._serialized_start=6927 + _globals['_GENERATIVEAWSMETADATA']._serialized_end=6950 + _globals['_GENERATIVECOHEREMETADATA']._serialized_start=6953 + _globals['_GENERATIVECOHEREMETADATA']._serialized_end=7749 + _globals['_GENERATIVECOHEREMETADATA_APIVERSION']._serialized_start=7250 + _globals['_GENERATIVECOHEREMETADATA_APIVERSION']._serialized_end=7392 + _globals['_GENERATIVECOHEREMETADATA_BILLEDUNITS']._serialized_start=7395 + _globals['_GENERATIVECOHEREMETADATA_BILLEDUNITS']._serialized_end=7592 + _globals['_GENERATIVECOHEREMETADATA_TOKENS']._serialized_start=7594 + _globals['_GENERATIVECOHEREMETADATA_TOKENS']._serialized_end=7692 + _globals['_GENERATIVEDUMMYMETADATA']._serialized_start=7751 + _globals['_GENERATIVEDUMMYMETADATA']._serialized_end=7776 + _globals['_GENERATIVEMISTRALMETADATA']._serialized_start=7779 + _globals['_GENERATIVEMISTRALMETADATA']._serialized_end=8036 + _globals['_GENERATIVEMISTRALMETADATA_USAGE']._serialized_start=7875 + _globals['_GENERATIVEMISTRALMETADATA_USAGE']._serialized_end=8026 + _globals['_GENERATIVEOLLAMAMETADATA']._serialized_start=8038 + _globals['_GENERATIVEOLLAMAMETADATA']._serialized_end=8064 + _globals['_GENERATIVEOPENAIMETADATA']._serialized_start=8067 + _globals['_GENERATIVEOPENAIMETADATA']._serialized_end=8322 + _globals['_GENERATIVEOPENAIMETADATA_USAGE']._serialized_start=7875 + _globals['_GENERATIVEOPENAIMETADATA_USAGE']._serialized_end=8026 + _globals['_GENERATIVEGOOGLEMETADATA']._serialized_start=8325 + _globals['_GENERATIVEGOOGLEMETADATA']._serialized_end=9197 + _globals['_GENERATIVEGOOGLEMETADATA_TOKENCOUNT']._serialized_start=8506 + _globals['_GENERATIVEGOOGLEMETADATA_TOKENCOUNT']._serialized_end=8632 + _globals['_GENERATIVEGOOGLEMETADATA_TOKENMETADATA']._serialized_start=8635 + _globals['_GENERATIVEGOOGLEMETADATA_TOKENMETADATA']._serialized_end=8860 + _globals['_GENERATIVEGOOGLEMETADATA_METADATA']._serialized_start=8862 + _globals['_GENERATIVEGOOGLEMETADATA_METADATA']._serialized_end=8973 + _globals['_GENERATIVEGOOGLEMETADATA_USAGEMETADATA']._serialized_start=8976 + _globals['_GENERATIVEGOOGLEMETADATA_USAGEMETADATA']._serialized_end=9165 + _globals['_GENERATIVEDATABRICKSMETADATA']._serialized_start=9200 + _globals['_GENERATIVEDATABRICKSMETADATA']._serialized_end=9463 + _globals['_GENERATIVEDATABRICKSMETADATA_USAGE']._serialized_start=7875 + _globals['_GENERATIVEDATABRICKSMETADATA_USAGE']._serialized_end=8026 + _globals['_GENERATIVEFRIENDLIAIMETADATA']._serialized_start=9466 + _globals['_GENERATIVEFRIENDLIAIMETADATA']._serialized_end=9729 + _globals['_GENERATIVEFRIENDLIAIMETADATA_USAGE']._serialized_start=7875 + _globals['_GENERATIVEFRIENDLIAIMETADATA_USAGE']._serialized_end=8026 + _globals['_GENERATIVENVIDIAMETADATA']._serialized_start=9732 + _globals['_GENERATIVENVIDIAMETADATA']._serialized_end=9987 + _globals['_GENERATIVENVIDIAMETADATA_USAGE']._serialized_start=7875 + _globals['_GENERATIVENVIDIAMETADATA_USAGE']._serialized_end=8026 + _globals['_GENERATIVEXAIMETADATA']._serialized_start=9990 + _globals['_GENERATIVEXAIMETADATA']._serialized_end=10239 + _globals['_GENERATIVEXAIMETADATA_USAGE']._serialized_start=7875 + _globals['_GENERATIVEXAIMETADATA_USAGE']._serialized_end=8026 + _globals['_GENERATIVEMETADATA']._serialized_start=10242 + _globals['_GENERATIVEMETADATA']._serialized_end=11025 + _globals['_GENERATIVEREPLY']._serialized_start=11028 + _globals['_GENERATIVEREPLY']._serialized_end=11190 + _globals['_GENERATIVERESULT']._serialized_start=11192 + _globals['_GENERATIVERESULT']._serialized_end=11256 + _globals['_GENERATIVEDEBUG']._serialized_start=11258 + _globals['_GENERATIVEDEBUG']._serialized_end=11317 # @@protoc_insertion_point(module_scope) diff --git a/weaviate/proto/v1/v6300/v1/generative_pb2.pyi b/weaviate/proto/v1/v6300/v1/generative_pb2.pyi index 1aa8e619c..41a6c3d37 100644 --- a/weaviate/proto/v1/v6300/v1/generative_pb2.pyi +++ b/weaviate/proto/v1/v6300/v1/generative_pb2.pyi @@ -109,7 +109,7 @@ class GenerativeAnyscale(_message.Message): def __init__(self, base_url: _Optional[str] = ..., model: _Optional[str] = ..., temperature: _Optional[float] = ...) -> None: ... class GenerativeAWS(_message.Message): - __slots__ = ("model", "temperature", "service", "region", "endpoint", "target_model", "target_variant", "images", "image_properties", "max_tokens") + __slots__ = ("model", "temperature", "service", "region", "endpoint", "target_model", "target_variant", "images", "image_properties", "max_tokens", "stop_sequences") MODEL_FIELD_NUMBER: _ClassVar[int] TEMPERATURE_FIELD_NUMBER: _ClassVar[int] SERVICE_FIELD_NUMBER: _ClassVar[int] @@ -120,6 +120,7 @@ class GenerativeAWS(_message.Message): IMAGES_FIELD_NUMBER: _ClassVar[int] IMAGE_PROPERTIES_FIELD_NUMBER: _ClassVar[int] MAX_TOKENS_FIELD_NUMBER: _ClassVar[int] + STOP_SEQUENCES_FIELD_NUMBER: _ClassVar[int] model: str temperature: float service: str @@ -130,7 +131,8 @@ class GenerativeAWS(_message.Message): images: _base_pb2.TextArray image_properties: _base_pb2.TextArray max_tokens: int - def __init__(self, model: _Optional[str] = ..., temperature: _Optional[float] = ..., service: _Optional[str] = ..., region: _Optional[str] = ..., endpoint: _Optional[str] = ..., target_model: _Optional[str] = ..., target_variant: _Optional[str] = ..., images: _Optional[_Union[_base_pb2.TextArray, _Mapping]] = ..., image_properties: _Optional[_Union[_base_pb2.TextArray, _Mapping]] = ..., max_tokens: _Optional[int] = ...) -> None: ... + stop_sequences: _base_pb2.TextArray + def __init__(self, model: _Optional[str] = ..., temperature: _Optional[float] = ..., service: _Optional[str] = ..., region: _Optional[str] = ..., endpoint: _Optional[str] = ..., target_model: _Optional[str] = ..., target_variant: _Optional[str] = ..., images: _Optional[_Union[_base_pb2.TextArray, _Mapping]] = ..., image_properties: _Optional[_Union[_base_pb2.TextArray, _Mapping]] = ..., max_tokens: _Optional[int] = ..., stop_sequences: _Optional[_Union[_base_pb2.TextArray, _Mapping]] = ...) -> None: ... class GenerativeCohere(_message.Message): __slots__ = ("base_url", "frequency_penalty", "max_tokens", "model", "k", "p", "presence_penalty", "stop_sequences", "temperature", "images", "image_properties")