All Classes Interface Summary Class Summary
Class
Description
Acknowledgement
Structure passed to acknowledgement handler called when a ACK
or NACK
frame is received.
AmazonCognitoAuth
Simplified factory to create an for Amazon Cognito.
AmqpClient
AMQP Client entry point.
AmqpConnection
Once connected to the broker or router, you get a connection.
AmqpMessage
Represents an AMQP message.
AmqpMessageBuilder
AmqpReceiver
Interface used to consume AMQP message as a stream of message.
AmqpSender
AMQP Sender interface used to send messages.
AndAuthorization
Allows to perform a logical 'and' between several authorizations
APIKeyHandler
An authentication handler that provides API Key support.
AppleIdAuth
Simplified factory to create an for Apple.
ArrayParserFactory
This interface is used to create able to parse serialized array structures.
Async
An asynchronous exit point for a test.
AsyncFile
Represents a file on the file-system which can be read from, or written to asynchronously.
AsyncFileLock
AsyncMap <K ,V >
An asynchronous map.
Attribute
An attribute is a simple matcher for policies.
AuthenticationHandler
Base interface for auth handlers.
AuthenticationProvider
User-facing interface for authenticating users.
Authorization
Interface representing any kind of authorization such as:
Role based authorization
Permission based authorization
Logical authorization (AND, OR, NOT)
Time based authorization (ie: allow access the last 5 days of the month, from 8am till 10am, etc.)
AuthorizationContext
The AuthorizationContext contains properties that can be used to match
authorizations.
AuthorizationHandler
Base interface for authorization handlers that provide authorization support.
AuthorizationProvider
The role of an AuthorizationProvider is to return a set of Authorization.
Authorizations
Represents a cache map of authorizations per provider.
AzureADAuth
Simplified factory to create an for Azure AD.
BaseBridgeEvent
Represents an event that occurs on the event bus bridge.
BasicAuthHandler
An auth handler that provides HTTP Basic Authentication support.
Bodies
BodyCodec <T >
A codec for encoding and decoding HTTP bodies.
BodyHandler
A handler which gathers the entire request body and sets it on the .
BodyProcessorFactory
This interface is used to build body processors.
BoxAuth
Simplified factory to create an for box.com.
BridgeEvent
Represents an event that occurs on the event bus bridge.
BridgeEvent
Represents an event that occurs on the event bus bridge.
CachingWebClient
An asynchronous cache aware HTTP / HTTP/2 client called CachingWebClient
.
CassandraClient
Eclipse Vert.x Cassandra client.
CassandraRowStream
A for consumption.
ChainAuth
Chain several authentication providers as if they were one.
ChainAuthHandler
An auth handler that chains to a sequence of handlers.
CircuitBreaker
An implementation of the circuit breaker pattern for Vert.x
ClientBuilder <C >
ClientWebSocket
Represents a client-side WebSocket.
CloudFoundryAuth
Simplified factory to create an for CloudFoundry UAA.
ClusteredSessionStore
A session store which stores sessions in a distributed map so they are available across the cluster.
ColumnDescriptor
Completion <T >
A completion object that emits completion notifications either succeeded or failed .
ConfigRetriever
Defines a configuration retriever that read configuration from
and tracks changes periodically.
ConnectionInitEvent
ConsulClient
A Vert.x service used to interact with Consul.
CookieSessionStore
A SessionStore that uses a Cookie to store the session data.
CorsHandler
A handler which implements server side http://www.w3.org/TR/cors/[CORS] support for Vert.x-Web.
Counter
An asynchronous counter that can be used to across the cluster to maintain a consistent count.
CredentialStorage
Used to represent persistent storage of credentials, this gives you a way to abstract
how you want to store them (in memory, database, other).
CSPHandler
Content Security Policy (CSP) is an added layer of security that helps to detect and mitigate certain types of
attacks, including Cross Site Scripting (XSS) and data injection attacks.
CSRFHandler
This handler adds a CSRF token to requests which mutate state.
Cursor
A cursor that reads progressively rows from the database, it is useful for reading very large result sets.
DatabaseMetadata
Contains static metadata about the backend database server
DatagramSocket
DB2Builder
Entry point for building DB2 clients.
DB2Connection
A connection to DB2 server.
DeliveryContext <T >
Encapsulates a message being delivered by Vert.x as well as providing control over the message delivery.
Destination
Represents a STOMP destination.
DestinationFactory
Interface implemented to customize the destination creation.
DigestAuthHandler
An auth handler that provides HTTP Basic Authentication support.
DnsClient
Provides a way to asynchronously lookup information from DNS servers.
DropboxAuth
Simplified factory to create an for Dropbox.
Endpoint
EndpointResolver
A resolver for endpoints.
ErrorHandler
A pretty error handler for rendering error pages.
EventBus
A Vert.x event-bus is a light-weight distributed messaging system which allows different parts of your application,
or different applications and services to communicate with each in a loosely coupled way.
EventBusCollector
The event bus collector listen to events on the Vert.x event bus and translate them
into reports.
EventBusService
for event bus services (service proxies).
ExecutionInputBuilderWithContext <C >
Holds a with a contextual object.
FacebookAuth
Simplified factory to create an for Facebook.
Failure
A failure provides the details of a failure that happened during the execution of a test case.
FailurePolicy <T >
FaviconHandler
A handler that serves favicons.
FileSystem
Contains a broad set of operations for manipulating files on the file system.
FileUpload
Represents a file-upload from an HTTP multipart form submission.
FormDataPart
FormLoginHandler
Handler that handles login from a form on a custom login page.
FoursquareAuth
Simplified factory to create an for Foursquare.
Frames
Utility methods to build common
Frame
s.
FreeMarkerTemplateEngine
A template engine that uses the FreeMarker library.
GiteeAuth
Simplified factory to create an for Gitee.
GithubAuth
Simplified factory to create an for Github.
GitLabAuth
Simplified factory to create an for GitLab.com.
GoogleAuth
Simplified factory to create an
OAuth2Auth
for Google.
GraphiQLHandler
A handler for GraphiQL resources.
GraphiQLHandlerBuilder
GraphQLHandler
A
Route
handler for GraphQL requests.
GraphQLHandlerBuilder
GraphQLWSHandler
GraphQLWSHandlerBuilder
GrpcClient
A gRPC client for Vert.x
GrpcClientBuilder <C >
GrpcClientRequest <Req ,Resp >
A request to a gRPC server.
GrpcClientResponse <Req ,Resp >
A response from a gRPC server.
GrpcReadStream <T >
GrpcServer
A gRPC server based on Vert.x HTTP server.
GrpcServerRequest <Req ,Resp >
GrpcServerResponse <Req ,Resp >
GrpcWriteStream <T >
HandlebarsTemplateEngine
A template engine that uses the Handlebars library.
HashingAlgorithm
Hashing Algorithm.
HashingStrategy
Hashing Strategy manager.
HealthCheckHandler
A Vert.x Web handler on which you register health check procedure.
HealthChecks
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
HerokuAuth
Simplified factory to create an for Heroku.
HotpAuth
An extension of AuthProvider which uses the one time passwords based on counter to perform authentication.
HSTSHandler
HTTP Strict Transport Security (HSTS)
RFC6797 .
HtdigestAuth
An extension of AuthProvider which is using .htdigest file as store
HtpasswdAuth
An extension of AuthProvider which is using htpasswd file as store
HttpClient
The API to interacts with an HTTP server.
HttpClientAgent
An asynchronous HTTP client.
HttpClientBuilder
HttpClientConnection
Represents an HTTP client connection.
HttpClientRequest
Represents a client-side HTTP request.
HttpClientResponse
Represents a client-side HTTP response.
HttpConnection
Represents an HTTP connection.
HttpEndpoint
for HTTP endpoint (REST api).
HttpHeaders
Contains a bunch of useful HTTP headers stuff:
methods for creating instances
often used Header names
method to create optimized
CharSequence
which can be used as header name and value
HttpRequest <T >
A client-side HTTP request.
HttpRequestHead
The state of the HTTP request head:
Method / URI
Headers
HttpResponse <T >
An HTTP response.
HttpResponseExpectation
Common expectations for HTTP responses.
HttpResponseHead
The state of the HTTP response head:
Status code / Message
Headers
HttpServer
An HTTP and WebSockets server.
HttpServerFileUpload
Represents an file upload from an HTML FORM.
HttpServerRequest
Represents a server-side HTTP request.
HttpServerResponse
Represents a server-side HTTP response.
IBMCloudAuth
Simplified factory to create an for IBM Cloud.
InfinispanSessionStore
An implementation of that relies on the Infinispan Java Client.
InputTrustHandler
Base input trust interface for handlers that verify the trust of the request.
InstagramAuth
Simplified factory to create an for Instagram.
JDBCConnection
JDBCPool
JDBCPool is the interface that allows using the Sql Client API with plain JDBC.
JsonFormatValidator
JsonParser
A parser class which allows to incrementally parse json elements and emit json parse events instead of parsing a json
element fully.
JsonPointer
JsonPointerIterator
The JsonPointerIterator is used by the read/write algorithms of the
JsonPointer
to read/write the querying data structure
Every method takes the currentValue as parameter, representing the actual value held by the query algorithm.
Implementations of this interface should be stateless, so they can be reused
You can implement this interface to query the structure you want using json pointers
JsonSchema
A Json-Schema holder.
JWTAuth
JWTAuthHandler
An auth handler that provides JWT Authentication support.
JWTAuthorization
Implementation of the JWT authorization provider.
KafkaAdminClient
Vert.x Kafka Admin client implementation
KafkaConsumer <K ,V >
Vert.x Kafka consumer.
KafkaConsumerRecord <K ,V >
Vert.x Kafka consumer record
KafkaConsumerRecords <K ,V >
Vert.x Kafka consumer records
KafkaHeader
Vert.x Kafka producer record header.
KafkaProducer <K ,V >
Vert.x Kafka producer.
KafkaProducerRecord <K ,V >
Vert.x Kafka producer record.
KeycloakAuth
Simplified factory to create an for Keycloak.
KeycloakAuthorization
Implementation of the Keycloak Authorization Provider.
LanguageHeader
A parsed language header.
LdapAuthentication
LinkedInAuth
Simplified factory to create an for LinkedIn.
LiveAuth
Simplified factory to create an for live.com Services.
LocalMap <K ,V >
Local maps can be used to share data safely in a single Vert.x instance.
LocalSessionStore
A session store which is only available on a single node.
Lock
An asynchronous exclusive lock which can be obtained from any node in the cluster.
LoggerFormatter
LoggerHandler
A handler which logs request information to the Vert.x logger.
MailAttachment
Represent a mail attachment that can be used in a MailMessage.
MailchimpAuth
Simplified factory to create an for Mailchimp.
MailClient
SMTP mail client for Vert.x
Measured
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
MediaType
This interface represents the most important attributes of an OpenAPI Operation.
Message <T >
Represents a message that is received from the event bus in a handler.
Message
MessageConsumer <T >
An event bus consumer object representing a stream of message to an
EventBus
address that can
be read from.
MessageProducer <T >
Represents a stream of message that can be written to.
MessageSource
Service type for data producer.
MethodOverrideHandler
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
MetricsService
The metrics service mainly allows to return a snapshot of measured objects.
MetricsService
The metrics service mainly allows to return a snapshot of measured objects.
This service is derived and adapted from MetricsService
in the vertx-dropwizard-metrics module.
MicroProfileAuthorization
Implementation of the Microprofile MP-JWT 1.1 RBAC based on the access token groups key.
MIMEHeader
MongoClient
A Vert.x service used to interact with MongoDB server instances.
MongoDataSource
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
MongoGridFsClient
MqttAuthenticationExchangeMessage
Represents an MQTT AUTH message
MqttClient
An MQTT client
MqttConnAckMessage
Represents an MQTT CONNACK message
MqttDisconnectMessage
Represents an MQTT CONNACK message
MqttEndpoint
Represents an MQTT endpoint for point-to-point communication with the remote MQTT client
MqttMessage
Represent the interface for each MQTT message
MqttPubAckMessage
Represents an MQTT PUBACK message
MqttPubCompMessage
Represents an MQTT PUBCOMP message
MqttPublishMessage
Represents an MQTT PUBLISH message
MqttPubRecMessage
Represents an MQTT PUBREC message
MqttPubRelMessage
Represents an MQTT PUBREL message
MqttServer
An MQTT server
MqttSubAckMessage
Represents an MQTT SUBACK message
MqttSubscribeMessage
Represents an MQTT SUBSCRIBE message
MqttTopicSubscription
Represents a subscription to a topic
MqttUnsubscribeMessage
Represents an MQTT UNSUBSCRIBE message
MSSQLBuilder
Entry point for building MSSQL clients.
MSSQLConnection
A connection to Microsoft SQL Server.
MultipartForm
A multipart form.
MultiTenantHandler
A handler which selectively executes another handler if a precondition is met.
MVELTemplateEngine
A template engine that uses the Handlebars library.
MySQLBuilder
Entry point for building MySQL clients.
MySQLClient
An interface to define MySQL specific constants or behaviors.
MySQLConnection
An interface which represents a connection to MySQL server.
NetClient
A TCP client.
NetServer
Represents a TCP server
NetSocket
Represents a socket-like interface to a TCP connection on either the
client or the server side.
NotAuthorization
Allows to perform a logical 'not' of the specified authorization
OAuth2Auth
OAuth2AuthHandler
An auth handler that provides OAuth2 Authentication support.
OAuth2WebClient
An asynchronous OAuth2/OIDC aware HTTP / HTTP/2 client called WebClientOAuth2
.
OAuthFlow
Represents an OAuth Flow Object (the configuration).
OAuthFlows
Represents an OAuth Flows Object.
ObjectParserFactory
This interface is used to create able to parse serialized object structures.
OpenAPIContract
OpenAPIRoute
OpenIDConnectAuth
Simplified factory to create an
OAuth2Auth
for OpenID Connect.
Operation
This interface represents the most important attributes of an OpenAPI Operation.
OracleBuilder
Entry point for building Oracle clients.
OracleClient
An interface to define Oracle specific constants or behaviors.
OracleConnection
A connection to Oracle Database.
OrAuthorization
Allows to perform a logical 'or' between several authorizations
OtpAuthHandler
An auth handler that provides One Time Password (Multi-Factor) Authentication support.
OtpKeyGenerator
Otp key generator.
Parameter
This interface represents the most important attributes of an OpenAPI Parameter.
Parameter
ParameterProcessorFactory
This interface is used to build parameter processors supported on every .
Parameters
ParsedHeaderValue
ParsedHeaderValues
A container with the request's headers that are meaningful enough to be parsed
Contains:
Accept -> MIME header, parameters and sortable
Accept-Charset -> Parameters and sortable
Accept-Encoding -> Parameters and sortable
Accept-Language -> Parameters and sortable
Content-Type -> MIME header and parameters
Parsers
Path
This interface represents the most important attributes of an OpenAPI Parameter.
PebbleTemplateEngine
A template engine that uses the Pebble library.
PermissionBasedAuthorization
Represents a permission Note that the permission can optionally be assigned
to a specific resource
PgBuilder
Entry point for building PostgreSQL clients.
PgChannel
A channel to Postgres that tracks the subscription to a given Postgres channel using the LISTEN/UNLISTEN
commands.
PgConnection
A connection to Postgres.
PgSubscriber
A class for managing subscriptions using LISTEN/UNLISTEN
to Postgres channels.
Pipe <T >
Pipe data from a
ReadStream
to a
WriteStream
and performs flow control where necessary to
prevent the write stream buffer from getting overfull.
PlatformHandler
Base platform interface for handlers that provide functionality to the application platform.
PolicyBasedAuthorizationProvider
Pool
A connection pool which reuses a number of SQL connections.
PreparedQuery <T >
A query for a prepared statement allowing parameterized execution of the query, this query will use
a prepared statement.
PreparedStatement
A prepared statement, the statement is pre-compiled and it's more efficient to execute the statement for multiple times.
PrometheusRequestHandler
An interface for creating handlers to expose Prometheus metrics via an HTTP endpoint.
PrometheusScrapingHandler
A Vert.x Web
Route
handler for Prometheus metrics scraping.
PropertyFileAuthentication
PropertyFileAuthorization
PropertyKind <T >
The kind of the property, this can be used to fetch some specific property of the
execution result
.
ProtocolUpgradeHandler
Base interface for handlers that perform protocol upgrades.
PugTemplateEngine
A template engine that uses Pug.
Query <T >
A query.
RabbitMQClient
NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
RabbitMQConsumer
A stream of messages from a rabbitmq queue.
RabbitMQMessage
Represent a message received message received in a rabbitmq-queue.
RabbitMQPublisher
A reliable publisher that
Queues up messages internally until it can successfully call basicPublish.
ReadStream <T >
Represents a stream of items that can be read from.
RecordParser
A helper class which allows you to easily parse protocols which are delimited by a sequence of bytes, or fixed
size records.
RedirectAuthHandler
An auth handler that's used to handle auth by redirecting user to a custom login page.
Redis
A simple Redis client.
RedisAPI
Auto generated Redis API client wrapper.
RedisCluster
Utilities for Redis cluster.
RedisConnection
A simple Redis client.
RedisDataSource
Service type for Redis data source.
RedisSessionStore
A SessionStore that uses a Redis to store the sessions and associated data.
Ref
JsonObject $ref
resolver.
RequestBody
RequestBody
This interface represents the most important attributes of an OpenAPI Operation.
RequestExtractor
RequestParameter
Request parameter holder
RequestParameter
RequestParameters
Container for request parameters
RequestPredicate
Request predicate
RequestPredicateResult
RequestValidator
Response
ResponseContentTypeHandler
A handler which sets the response content type automatically according to the best Accept
header match.
ResponseParameter
ResponseTimeHandler
Handler which adds a header `x-response-time` in the response of matching requests containing the time taken
in ms to process the request.
ResultSet
It is like AsyncResultSet
, but adapted for Vert.x.
RetryPolicy
A policy for retry execution.
RockerTemplateEngine
A template engine that uses the Rocker library.
RoleBasedAuthorization
Represents a role.
Route
A route is a holder for a set of criteria which determine whether an HTTP request or failure should be routed
to a handler.
Router
A router receives request from an
HttpServer
and routes it to the first matching
Route
that it contains.
RouterBuilder
Interface to build a Vert.x Web from an OpenAPI 3 contract.
RoutingContext
Represents the context for the handling of a request in Vert.x-Web.
Row
RowIterator <R >
An iterator for processing rows.
RowMapper <T >
Map a to an arbitrary T
object.
RowSet <R >
The execution result of the row set of a query provided as
, commonly used as a RowSet|
.
RowStream <T >
A row oriented stream.
SalesforceAuth
Simplified factory to create an for Salesforce.
SchemaRepository
A repository is a holder of dereferenced schemas, it can be used to create validator instances for a specific schema.
ScopeAuthorization
Scope is a mechanism in OAuth 2.0 to limit an application's access to a user's account.
Security
An authentication handler factory.
SecurityAudit
SecurityAuditLoggerHandler
A handler that logs security audit events.
SecurityPolicyHandler
Base security policy interface for handlers that provide HTTP security related headers.
SecurityRequirement
A Security requirement is an object that contains the names of the security schemes that apply to the operation.
SecurityScheme
Represents a Security Scheme Object.
Server
This interface represents the most important attributes of an OpenAPI Server.
ServerEndpoint
A physical server of an endpoint.
ServerFrame
Structure passed to server handler when receiving a frame.
ServerInteraction
Request interaction with an endpoint, mostly callbacks to gather statistics.
ServerWebSocket
Represents a server side WebSocket.
ServerWebSocketHandshake
A server WebSocket handshake, allows to control acceptance or rejection of a WebSocket.
ServiceDiscovery
Service Discovery main entry point.
ServiceExporter
The service exporter allows integrate other discovery technologies with the Vert.x service discovery.
ServiceImporter
The service importer allows integrate other discovery technologies with the Vert.x service discovery.
ServicePublisher
The publisher is used by the importer to publish or unpublish records.
ServiceReference
Once a consumer has chosen a service, it builds a
ServiceReference
managing the binding with the chosen
service provider.
Session
Represents a browser session.
SessionHandler
A handler that maintains a
Session
for each browser
session.
SessionStore
A session store is used to store sessions for an Vert.x-Web web app
SharedData
Shared data allows you to share data safely between different parts of your application in a safe way.
ShopifyAuth
Simplified factory to create an for Shopify.
SimpleAuthenticationHandler
A user customizable authentication handler.
SockJSHandler
A handler that allows you to handle SockJS connections from clients.
SockJSSocket
You interact with SockJS clients through instances of SockJS socket.
SoundcloudAuth
Simplified factory to create an for SoundCloud.
SqlAuthentication
SqlAuthorization
Factory interface for creating instances that use the Vert.x SQL client.
SqlClient
Defines common SQL client operations with a database server.
SqlConnection
A connection to the database server.
SqlOutParam
Tag if a parameter is of type OUT or INOUT.
SqlResult <T >
An interface that represents the execution result of an operation on the database server.
SqlTemplate <I ,R >
An SQL template.
SqlUserUtil
Utility to create users/roles/permissions.
StaticHandler
A handler for serving static resources from the file system or classpath.
StompClient
Defines a STOMP client.
StompClientConnection
Once a connection to the STOMP server has been made, client receives a
StompClientConnection
, that let
send and receive STOMP frames.
StompServer
Defines a STOMP server.
StompServerConnection
Class representing a connection between a STOMP client a the server.
StompServerHandler
STOMP server handler implements the behavior of the STOMP server when a specific event occurs.
StreamBase
Base interface for a stream.
StripeAuth
Simplified factory to create an for Stripe.
StyledParameterProcessorFactory
This interface is used to build complex parameter processors supported only in cookie & query.
TcpEventBusBridge
TCP EventBus bridge for Vert.x
TemplateEngine
A template template uses a specific template and the data in a routing context to render a resource into a buffer.
TemplateHandler
A handler which renders responses using a template engine and where the template name is selected from the URI
path.
TestCase
A test case object can be used to create a single test.
TestCaseReport
Report the execution of a test case.
TestCompletion
This object provides callback-ability for the end of a test suite, the completion succeeds
when all tests pass otherwise it fails.
TestContext
The test context is used for performing test assertions and manage the completion of the test.
TestResult
The result of a test.
TestSuite
A named suite of test cases that are executed altogether.
TestSuiteReport
The test suite reports is basically a stream of events reporting the test suite execution.
ThymeleafTemplateEngine
A template engine that uses the Thymeleaf library.
TimeoutHandler
Handler that will timeout requests if the response has not been written after a certain time.
TotpAuth
An extension of AuthProvider which uses the one time passwords based on time to perform authentication.
Transaction
A transaction.
Tuple
A general purpose tuple.
TupleMapper <T >
Map an arbitrary T
object to a .
TupleParserFactory
This interface is used to create able to parse serialized object structures.
TwitterAuth
Simplified factory to create an for Twitter.
UploadScalar
UriTemplate
A URI template that follows the
rfc6570 level 4.
User
Represents an authenticates User and contains operations to authorise the user.
UserContext
A web user is extended user coupled to the context and is used to perform verifications
and actions on behalf of the user.
ValidatableRequest
ValidatableResponse
ValidatedRequest
ValidatedResponse
ValidationHandler
ValidationHandlerBuilder
Builder for a .
Validator
A validator, validates some input object using a well known schema.
Variables
Holds a set of name/value pairs where each value can be a String
or a List
or a Map
.
VertxContextPRNG
A secure non blocking random number generator isolated to the current context.
Watch <T >
Watches are a way of specifying a view of data (e.g. list of nodes, KV pairs, health checks)
which is monitored for updates.
WatchResult <T >
WebAuthn4J
WebAuthn4JHandler
An auth handler that provides FIDO2 WebAuthN Relay Party support.
WebClient
An asynchronous HTTP / HTTP/2 client called WebClient
.
WebClientSession
An asynchronous sessions aware HTTP / HTTP/2 client called WebClientSession
.
WebEnvironment
Utility API to verify which environment is the web application running.
WebSocket
Common WebSocket implementation.
WebSocketBase
Base WebSocket implementation.
WebSocketClient
An asynchronous WebSocket client.
WildcardPermissionBasedAuthorization
Represents a wildcard permission (ie: 'manage:order:*' '*:orders', '*', etc.)
WriteStream <T >
Represents a stream of data that can be written to.
XFrameHandler
The X-Frame-Options HTTP response header can be used to indicate whether or not a browser should be allowed to render
a page in a
,
,
or
.