All Classes and Interfaces
Class
Description
A
RuntimeException
that is raised to signal a Subscriber
that the StreamMessage
it subscribed to has been aborted by StreamMessage.abort()
.A base class for JUnit5 extensions that allows implementations to control whether the callbacks are run
around the entire class, like
BeforeAll
or AfterAll
, or around each test method, like
BeforeEach
or AfterEach
.Abstract class for implementing ArmeriaAutoConfiguration.
Provides base implementation for an
Authorizer
that defines custom
AuthSuccessHandler
/AuthFailureHandler
s.A skeletal
Backoff
implementation.A skeletal
HttpVfs
implementation for accessing file system with blocking I/O.A
Client
decorator that handles failures of remote invocation based on circuit breaker pattern.A skeletal builder implementation that builds a new
AbstractCircuitBreakerClient
or
its decorator function.An abstract builder class for building a
CircuitBreakerMapping
based on a combination of host, method and path.A skeletal builder implementation for
ClientOptions
.An abstract
Client
decorator that limits the concurrent number of active requests.A skeletal builder implementation for
CuratorFramework
.A skeletal builder implementation for DNS resolvers.
A skeletal builder implementation for a
DynamicEndpointGroup
and its subtypes.A skeletal
EndpointSelector
implementation.A skeletal GraphQL HTTP service implementation.
A skeletal builder implementation for creating a new
HealthCheckedEndpointGroup
.A skeletal
HttpFile
implementation.A skeletal builder class which helps easier implementation of
HttpFileBuilder
or
AggregatedHttpFileBuilder
.A skeletal builder implementation for
HttpMessage
.Builds a new
HttpRequest
.A skeletal
HttpService
for easier HTTP service implementation.A skeletal
HttpVfs
implementation.A skeletal builder implementation for
JettyServiceBuilder
in Jetty 9 and Jetty 10+ modules.A skeletal
Listenable
implementation.A skeletal implementation of gRPC message deframer.
Builds an implementing class of
AbstractMetricCollectingBuilder
instance.A configuration option.
Creates a new option instance.
A set of configuration options and their respective values.
A holder of a value of an
AbstractOption
.Provides the information required for building a
RequestContext
.A
Client
decorator that handles failures of remote invocation and retries requests.Builds a new
AbstractRetryingClient
or its decorator function.A skeletal builder implementation for
RetryRule
, RetryRuleWithContent
,
CircuitBreakerRule
and CircuitBreakerRuleWithContent
.A skeletal builder implementation for
RetryRuleWithContent
and CircuitBreakerRuleWithContent
.Decorates a
Service
to throttle incoming requests.An
AbstractUnaryGrpcService
can be used to implement a gRPC service without depending on gRPC stubs.An
AbstractUnsafeUnaryGrpcService
can be used to implement a gRPC service without depending on gRPC
stubs.Skeletal
Unwrappable
implementation.A skeletal builder implementation for
WebClient
.Consumes the
RequestLog
s produced by a Service
, usually for logging purpose.An OAuth 2.0 request to obtain an access token.
Annotation for an additional HTTP header.
The containing annotation type for
AdditionalHeader
.Annotation for an additional HTTP trailer.
The containing annotation type for
AdditionalTrailer
.A complete body part whose headers and content are readily available.
A complete HTTP file whose attributes and content are readily available.
Builds an
AggregatedHttpFile
from an HttpData
.A complete HTTP message whose content is readily available as a single
HttpData
.A complete HTTP headers and content that are readily available.
A complete HTTP request whose content is readily available as a single
HttpData
.A complete HTTP response whose content is readily available as a single
HttpData
.A complete multipart whose body parts are readily available.
An
AggregationOptions
to control the aggregation behavior of HttpMessage
.A builder for
AggregationOptions
.A helper class to support caching the aggregated result of
HttpMessage
.An
HttpService
which is defined by a Path
or HTTP method annotations.A builder class for binding an
HttpService
fluently.Spring Boot
Configuration
that provides Armeria integration.BeanPostProcessor
implementation that autowires annotated fields, setter methods, and arbitrary
config methods.Spring Boot
Configuration
that provides Armeria integration.A Dropwizard
ConfiguredBundle
that routes requests through an
Armeria Server
rather than the default Jetty server.An auto-configuration for Armeria-based
WebClient
.A configurator to configure a
WebClientBuilder
for an ArmeriaClientHttpConnector
.An
HttpClient.Factory
for creating ArmeriaHttpClient
.A
ReactorHttpExchangeAdapter
implementation for the Armeria WebClient
.A builder for creating a new instance of
ArmeriaHttpExchangeAdapter
.An implementation of
AsyncClientHttpEngine
based on Armeria WebClient
.A deframer of messages transported in the gRPC wire format.
A framer of messages for transport with the gRPC wire protocol.
A
ReactiveWebServerFactory
which is used to create a new ArmeriaWebServer
.An auto-configuration for a reactive web server.
An optional helper class to build
ResteasyClient
using ResteasyClientBuilder
interface
as below.Interface used to configure a service on the default armeria server.
A
SmartLifecycle
for start and stop control of Armeria Server
.Settings for armeria servers.
Configurations for the access log.
Configurations for the HTTP content encoding.
Properties for internal services such as
DocService
, PrometheusExpositionService
, and
HealthCheckService
.Port and protocol settings.
A
Configuration
to enable actuator endpoints on an Armeria server.An
Exception
that contains enough information to convert it to a gRPC status.An object that may hold resources until it is closed.
Provides support for implementing
AsyncCloseable
or ListenableAsyncCloseable
.A utility class that bridges the gap between
CompletionStage
and AsyncMethodCallback
.A
ServerInterceptor
that is able to asynchronously execute the interceptor without blocking the
caller thread.Annotation for mapping an attribute of the given
AttributeKey
, retrieved
from a RequestContext
, onto the following elements.An immutable
Attributes
that holds attributes which can be accessed via AttributeKey
.A builder for
Attributes
.Provides the getter methods to
Attributes
and ConcurrentAttributes
.Sets entries for building an
Attributes
or updating ConcurrentAttributes
.A callback which is invoked to handle an authorization failure indicated by
Authorizer
.Provides a status of the request authorization operation, optionally combined with
AuthSuccessHandler
and AuthFailureHandler
to facilitate custom status handling.Determines whether a given
data
is authorized for the service registered in.Decorates an
HttpService
to provide HTTP authorization functionality.Builds a new
AuthService
.A callback which is invoked to handle an authorization success indicated by
Authorizer
.The authorization token in
HttpHeaderNames.AUTHORIZATION
header.A utility class that provides singleton instances of authorization token extractor functions.
Controls back off between attempts in a single retry operation.
Wraps an existing
Backoff
.Stores configurations of a single Token-Bucket bandwidth limit.
The bearer token of
HTTP basic access authentication.
Specifies that the annotated service method must be invoked from the
blocking task executor
instead of an event loop thread.
Provides an executor interface which is used for potentially long-running tasks which may block I/O threads.
A builder that is useful for creating a
ScheduledExecutorService
.A blocking web client that waits for an
HttpResponse
to be fully aggregated.Prepares and executes a new
HttpRequest
for BlockingWebClient
.A body part entity.
A builder class for creating
BodyPart
instances.A
BlockHoundIntegration
for the brave module.A built-in property exported by
RequestContextExporter
.A
RequestConverterFunction
which converts a binary body of the
AggregatedHttpRequest
to one of byte[]
or HttpData
depending on the
expectedResultType
.A
ResponseConverterFunction
which creates an HttpResponse
when:
the result
is an instance of HttpData
or byte[]
the result
is an instance of Publisher
or Stream
while the
"content-type"
of the ResponseHeaders
is "application/binary"
or
"application/octet-stream"
Note that this ResponseConverterFunction
is applied to an annotated service by default,
so you don't have to specify this converter explicitly.Represents binary data.
A
StreamMessage
that publishes bytes with HttpData
.Directives for HTTP caching mechanisms in requests or responses.
A
RuntimeException
raised when a requested invocation is forced to stop before its completion.A
RuntimeException
that is raised to notify StreamMessage.whenComplete()
when a
Subscriber
has cancelled its Subscription
.Builds a new
CorsPolicy
.A circuit breaker, which tracks the number of
success/failure requests and detects a remote service failure.
Builds a
CircuitBreaker
instance using builder pattern.A callback that is invoked for each request by
CircuitBreakerClient
.An
HttpClient
decorator that handles failures of HTTP requests based on circuit breaker pattern.Builds a new
CircuitBreakerClient
or its decorator function.A handler used by a
CircuitBreakerClient
to integrate with a circuit breaker.A
CircuitBreakerDecision
that determines a Response
as
a CircuitBreakerDecision.success()
or CircuitBreakerDecision.failure()
, or CircuitBreakerDecision.ignore()
s a Response
.A functional interface that represents a mapper factory, mapping a combination of host, method and path
to a
CircuitBreaker
.The listener interface for receiving
CircuitBreaker
events.A skeletal
CircuitBreakerListener
implementation in order for a user to implement only the methods
what he or she really needs.Returns a
CircuitBreaker
instance from remote invocation parameters.Builder class for building a
CircuitBreakerMapping
based on a combination of host, method and path.An
RpcClient
decorator that handles failures of RPC remote invocation based on
circuit breaker pattern.Builds a new
CircuitBreakerRpcClient
or its decorator function.Determines whether a
Response
should be reported as a success or failure to a
CircuitBreaker
.A builder for creating a new
CircuitBreakerRule
.Determines whether a
Response
should be reported as a success or failure to a
CircuitBreaker
using the content of the Response
.A builder for creating a new
CircuitBreakerRuleWithContent
.Defines the states of circuit breaker.
A source which is used to get a client address.
Provides client authentication for the OAuth 2.0 requests,
as per [RFC6749], Section 2.3.
Deprecated.
Creates a new client that connects to the specified
URI
using the builder pattern.Provides the construction parameters of a client.
Directives for HTTP caching mechanisms in requests.
Creates a new
ClientCacheControl
using the builder pattern.Returns a circuit breaker implementation from remote invocation parameters.
A holder class which has the timing information about a connection attempt before a client
sends a
Request
.Builds a new
ClientConnectionTimings
.Creates a new
ClientDecoration
using the builder pattern.Creates and manages clients.
Builds a new
ClientFactory
.A
ClientFactory
option.A set of
ClientFactoryOption
s and their respective values.A value of a
ClientFactoryOption
.Creates a new
ClientFactory
dynamically via Java SPI (Service Provider Interface).A
Observation.Context
which may be used in conjunction with ObservationClient
to implement custom ObservationConvention
s or ObservationHandler
s.A client option.
A set of
ClientOption
s and their respective values.Creates a new
ClientOptions
using the builder pattern.A value of a
ClientOption
.Builds a new
ClientRequestContext
.Captures the
ClientRequestContext
s created by the current thread.Wraps an existing
ClientRequestContext
.Creates a new client that connects to a specified
URI
.A
RuntimeException
raised when the connection to the remote peer has been closed unexpectedly.A
RuntimeException
that is raised when a StreamMessage
or an HTTP/2 stream
has been closed unexpectedly.A close
WebSocketFrame
.A root node representing a
Cluster
.A snapshot of a
Cluster
resource.A resource object for a
Cluster
.Provides the common shared thread pools and
EventLoopGroup
s which is used when not overridden.An
RpcResponse
implementation which is initially incomplete and can be completed later.Provides the common actions that are useful when handling a
CompletionStage
.Represents an exception that is a composite of one or more other exceptions.
Represents a message compressor.
Limits the concurrency of client requests.
Builds a
ConcurrencyLimit
.An
HttpClient
decorator that limits the concurrent number of active HTTP requests.A
TimeoutException
raised when a request is not sent from ConcurrencyLimitingClient
due to timeout.An
Attributes
supporting concurrency of retrievals and updates.Listens to the client connection pool events.
A skeletal
ConnectionPoolListener
implementation in order for a user to implement only the methods
what he or she really needs.A
ConnectionPoolListener
that wraps an existing ConnectionPoolListener
.CONNECT proxy configuration.
Sets properties for building a Consul client.
A Consul-based
EndpointGroup
implementation that retrieves the list of Endpoint
s
from Consul using Consul's HTTP API and updates the
Endpoint
s periodically.A builder class for
ConsulEndpointGroup
.Builds a new
ConsulUpdatingListener
, which registers the server to Consul cluster.Specifies a media type which would be consumed by the service method or class.
An alias for
@Consumes(MediaTypeNames.APPLICATION_BINARY)
.The containing annotation type for
Consumes
.An alias for
@Consumes(MediaTypeNames.JSON)
.An alias for
@Consumes(MediaTypeNames.OCTET_STREAM)
.An alias for
@Consumes(MediaTypeNames.PROTOBUF)
.An alias for
@Consumes(MediaTypeNames.PLAIN_TEXT_UTF_8)
.A container
TypeSignature
.Representation of the Content-Disposition type and parameters as defined in RFC 6266.
A builder class for creating
ContentDisposition
.Produces the preview of
RequestLog
.A factory creating a
ContentPreviewer
.A builder which builds a
ContentPreviewerFactory
.Builds a new
ContentPreviewingClient
.Builds a new
ContentPreviewingService
.A
RuntimeException
raised when the length of request or response content exceeds its limit.Builds a new
ContentTooLargeException
.A delegating
BiConsumer
that makes sure an underlying BiConsumer is
executed within the RequestContext
.A delegating
BiFunction
that makes sure an underlying BiFunction is
executed within the RequestContext
.A delegating
BlockingTaskExecutor
that sets the RequestContext
before executing
any submitted tasks.A delegating
Callable
that makes sure an underlying Callable is
executed within the RequestContext
.A delegating
Consumer
that makes sure an underlying Consumer is
executed within the RequestContext
.A delegating
EventLoop
that sets the RequestContext
before executing any submitted tasks.A delegating
Executor
that makes sure all submitted tasks are
executed within the RequestContext
.A delegating
ExecutorService
that makes sure all submitted tasks are
executed within the RequestContext
.A delegating
Function
that makes sure an underlying Function is
executed within the RequestContext
.A delegating
Runnable
that makes sure an underlying Runnable is
executed within the RequestContext
.A delegating
ScheduledExecutorService
that sets the RequestContext
before executing any
submitted tasks.A holder of
RequestContext
.A
ContextPathAnnotatedServiceConfigSetters
builder which configures an AnnotatedService
under a set of context paths.A builder class for binding a
decorator
with Route
fluently
under a set of context paths.A builder class for binding an
HttpService
fluently.Builds
ServiceConfig
s for a ServerBuilder
.An interface defining an
HTTP cookie.
Builds a
Cookie
.Decorates an
HttpClient
to set cookies to Cookie
header of outgoing HttpRequest
and
store cookies from Set-Cookie
headers of incoming HttpResponse
.A
Cookie
container for a client.A
BlockHoundIntegration
for the core module.Returns a
CoroutineContext
from a given ServiceRequestContext
.Configures a coroutine context for annotated services and Kotlin suspending functions.
Decorates an
HttpService
to configure the coroutine context which is used as an initial context
of annotated services' suspending functions.Cross-Origin Resource Sharing
(CORS) configuration.
A
CorsService
decorator for annotated HTTP services.A factory which creates a
CorsService
decorator when only one CorsDecorator
is added.The containing annotation type for
CorsDecorator
.A factory which creates a
CorsService
decorator when two or more CorsDecorator
s are added.Contains information of the CORS policy with the specified origins.
Builds a new
CorsPolicy
.Decorates an
HttpService
to add the
Cross-Origin Resource Sharing
(CORS) support.Builds a new
CorsService
or its decorator function.Builds a
ZooKeeperDiscoverySpec
for
Curator Service Discovery.Builds a
ZooKeeperRegistrationSpec
for
Curator Service Discovery.An exception indicating that a client detected cyclical redirections.
A configuration class which creates an
DataBufferFactoryWrapper
.A
DecoratingClient
that requests and decodes HTTP encoding (e.g., gzip) that has been applied to the
content of an HttpResponse
.A builder class for
DecodingClient
.A
DecoratingService
that requests and decodes HTTP encoding (e.g., gzip) that has been applied to the
content of an HttpRequest
.Represents a message decompressor.
Decorates a
Client
.A functional interface that enables building a
SimpleDecoratingHttpClient
with
ClientBuilder.decorator(DecoratingHttpClientFunction)
.A functional interface that enables building a
SimpleDecoratingHttpService
with
HttpService.decorate(DecoratingHttpServiceFunction)
.A functional interface that enables building a
SimpleDecoratingRpcClient
with
ClientBuilder.rpcDecorator(DecoratingRpcClientFunction)
.A functional interface that enables building a
SimpleDecoratingRpcService
with
RpcService.decorate(DecoratingRpcServiceFunction)
.A builder class for binding a
decorator
with Route
fluently.Specifies a
DecoratingHttpServiceFunction
class which handles an HttpRequest
before invoking
an annotated service method.Specifies a
DecoratorFactoryFunction
class which is a factory to create a decorator.A decorator factory which is used for a user-defined decorator annotation.
The containing annotation type for
Decorator
.Specifies the default value of an optional parameter.
A
StreamMessage
which buffers the elements to be signaled into a Queue
.A default duplicator.
A
StreamMessage
whose stream is published later by another StreamMessage
.A deframed message.
A
ResponseConverterFunction
provider interface which provides a
ResponseConverterFunction
that converts an object of the given type to an HttpResponse
using the delegating ResponseConverterFunction
.Annotation for mapping
HttpMethod.DELETE
onto specific method.Specifies a delimiter of a parameter.
Injects dependencies that are specified in
RequestConverter.value()
,
ResponseConverter.value()
, ExceptionHandler.value()
, Decorator.value()
and
DecoratorFactory.value()
.An annotation used in annotated HTTP service.
Description of a type, a field, a method or a parameter.
Metadata about a descriptive type.
Creates a new
DescriptiveTypeInfo
loaded dynamically via Java SPI (Service Provider Interface).A descriptive
TypeSignature
.Represents a direct connection without a proxy.
Builds a new
DnsAddressEndpointGroup
that sources its Endpoint
list from the A
or
AAAA
DNS records of a certain hostname.A cache for DNS responses.
A builder for
DnsCache
.Listens to the
DnsCache
events.Listens to the result of querying
DnsRecord
s.Builds an
AddressResolverGroup
which builds AddressResolver
s that update DNS caches
automatically.DynamicEndpointGroup
which resolves targets using DNS
SRV records.Builds a new
DnsServiceEndpointGroup
that sources its Endpoint
list from the SRV
DNS records of a certain hostname.DynamicEndpointGroup
which resolves targets using DNS TXT
records.Builds a new
DnsTextEndpointGroup
that sources its Endpoint
list from the TXT
DNS records of a certain hostname.A
TimeoutException
raised when a response has not been received from a DNS server within timeout.Builds a new
DocService
.Configures a
DocService
built by Armeria auto configuration.A filter which includes or excludes service methods when building a
DocService
.Generates the
ServiceSpecification
s of the supported Service
s.A supporting base class for implementing the standard pattern of extracting docstrings
from arbitrary files in a particular classpath location.
Processor that creates a properties file based on the JavaDoc/KDoc description of parameters for interfaces.
An
InetSocketAddress
that refers to a Unix domain socket path.Provides the convenient factory methods for
DropwizardMeterRegistry
with more sensible defaults for
NamingConvention
and HierarchicalNameMapper
.A dynamic
EndpointGroup
.Builds a new
DynamicEndpointGroup
.Sets properties for building
DynamicEndpointGroup
.An
EndpointGroupException
raised when the resolution of an EndpointGroup
fails
because there are no Endpoint
s in the EndpointGroup
.An exception which is thrown when an
HttpResponse
without any headers
or body is attempted to be sent over the wire.Decorates an
HttpService
to apply HTTP encoding (e.g., gzip) to an HttpService
.Builds a new
EncodingService
or its decorator function.A remote endpoint that refers to a single host.
A list of
Endpoint
s.A
RuntimeException
raised when the resolution of an EndpointGroup
fails.Metadata about the endpoints exposed by a
Service
.Creates a new
EndpointInfo
using the builder pattern.Endpoint
selection strategy that creates a EndpointSelector
.An
EndpointGroupException
raised when an EndpointGroup
fails to resolve
an Endpoint
within a configured selection timeout.Selects an
Endpoint
from an EndpointGroup
.A snapshot of a
ClusterLoadAssignment
resource.A resource object for a
ClusterLoadAssignment
.Metadata about an enum type.
Metadata about an enum value.
A Eureka-based
EndpointGroup
implementation.Builds a
EurekaEndpointGroup
.A
ServerListener
which registers the current Server
to Eureka.Builds a
EurekaUpdatingListener
, which registers the server to Eureka.An immutable object that stores the count of events.
A
CompletableFuture
that warns the user if they call a method that blocks the event loop.An
Extension
that provides an EventLoopGroup
.An
Extension
that provides an EventLoopGroup
.A
TestRule
that provides an EventLoopGroup
.Provides methods that are useful for creating an
EventLoopGroup
.A
TestRule
that provides an EventLoopGroup
.Specifies an
ExceptionHandlerFunction
class which handles exceptions throwing from an
annotated service method.An interface for exception handler.
The containing annotation type for
ExceptionHandler
.Metadata about an exception type.
Provides methods that are useful for handling exceptions.
Deprecated.
Use
LoggingService
or log exceptions using
ServerBuilder.errorHandler(ServerErrorHandler)
instead.Represents whether to stream an
HttpRequest
or HttpResponse
.Generates a unique execution ID of each GraphQL request.
Holds a set of
ExportGroupBuilder.ExportEntry
s.Builds a new
ExportGroup
.Bridge class for Logback configuration.
An exception that is returned when a
CircuitBreaker.onError(long, TimeUnit, Throwable)
is invoked without a distinctive exception.An exception indicating that a request has been failed by circuit breaker.
A
RuntimeException
raised for falling through to the next something.Metadata about a field of a struct or an exception.
Creates a new
FieldInfo
using the builder pattern.The location of a field.
The requirement level of a field.
An
HttpService
that serves static files from a file system.Builds a new
FileService
and its FileServiceConfig
.FileService
configuration.An
HttpRequest
that filters objects as they are published.An
HttpResponse
that filters objects as they are published.A
StreamMessage
that filters objects as they are published.The system properties that affect Armeria's runtime behavior.
A Java SPI (Service Provider Interface) for the
Flags
values.Utility methods related with function composition.
Asynchronously transforms an
HttpResponse
into a T
type object.Prepares and executes a new
HttpRequest
for WebClient
, and asynchronously transforms an
HttpResponse
into a T
type object.Annotation for mapping
HttpMethod.GET
onto specific method.A
RuntimeException
raised when a server sent an
HTTP/2 GOAWAY frame with
the lastStreamId
less then the stream ID of the request.A
GoogleGrpcExceptionHandlerFunction
that provides a way to include details of a status into
a Metadata
.Deprecated.
Use
GoogleGrpcExceptionHandlerFunction
instead.Defines a structure of the Access Token Response, as per
[RFC6749], Section 5.1.
Builds an instance of
GrantedOAuth2AccessToken
.Deprecated.
Use
GraphQL.Builder
directly.A GraphQL request.
An
HttpService
that implements the GraphQL.Constructs a
GraphqlService
to serve GraphQL within Armeria.A
BlockHoundIntegration
for the gRPC module.Retrieves
CallOptions
from a given RequestContext
.Creates a new gRPC client that connects to the specified
URI
using the builder pattern.ClientOption
s to control gRPC-specific behavior.Creates a new gRPC client that connects to a
URI
or an EndpointGroup
.A factory that creates a gRPC client stub.
Specifies a
GrpcExceptionHandlerFunction
class which handles exceptions throwing from a gRPC service
or its methods.An interface that converts a
Throwable
into a gRPC Status
for gRPC exception handler.A builder for
GrpcExceptionHandlerFunction
.The containing annotation type for
GrpcExceptionHandler
.gRPC-related HTTP header names.
An implementation of
HealthImplBase
that determines the healthiness of a Server
and the healthiness of each gRPC service.Builds a
GrpcHealthCheckService
.A JSON marshaller for gRPC method request or response messages to and from JSON.
A builder for creating a new
GrpcJsonMarshaller
that serializes and deserializes a Message
to and from JSON.Creates a
MeterIdPrefix
from a RequestLog
.gRPC-related
SerializationFormat
instances.An
HttpService
that implements the gRPC wire protocol.Constructs a
GrpcService
to serve gRPC services from within Armeria.Deprecated.
Use
GrpcExceptionHandlerFunction
instead.Deprecated.
Use
GrpcWebTrailers
instead.Retrieves gRPC-Web trailers.
A builder for creating a new
GrpcJsonMarshaller
that serializes and deserializes a Message
to and from JSON.Annotation for mapping
HttpMethod.HEAD
onto specific method.Annotation for mapping an HTTP request header onto the following elements.
A function that masks the specified header value.
A sanitizer that sanitizes
HttpHeaders
.An
EndpointGroup
that filters out unhealthy Endpoint
s from an existing EndpointGroup
,
by sending periodic health check requests.A builder for creating a new
HealthCheckedEndpointGroup
that sends HTTP health check requests.Determines whether the
Server
is healthy.Provides the properties and operations required for sending health check requests.
An
HttpService
that responds with HTTP status "200 OK"
if the server is healthy and can
accept requests and HTTP status "503 Service Not Available"
if the server is unhealthy and cannot
accept requests.Builds a
HealthCheckService
.Interface used to configure a
HealthCheckService
on the default Armeria server.The result of health check with interval for next check.
A listener interface for receiving
HealthCheckService
update events.The result of a request handled by
HealthCheckUpdateHandler
.Converts a normalized HTTP/2 header name to another HTTP/1 header name.
Sends an
HttpRequest
to a remote Endpoint
.HTTP/2 data that contains a chunk of bytes.
Decodes a stream of
HttpObject
s to N objects.An entity of an HTTP message.
A file-like HTTP resource which yields an
HttpResponse
.The attributes of an
HttpFile
.A response converter implementation which creates an
HttpResponse
when the result
is
an instance of HttpFile
.Contains constant definitions for the HTTP header field names.
Immutable HTTP/2 headers.
Builds an
HttpHeaders
.User provided options for customizing
HttpJsonTranscodingService
.A builder for
HttpJsonTranscodingOptions
.A naming rule to map
QueryParams
of an HttpRequest
to fields in a Message
for
HTTP-JSON transcoding endpoint.A streamed HTTP/2 message.
Sets properties for building an
HttpMessage
.HTTP request method.
The common interface for HTTP/2 message objects,
HttpHeaders
and HttpData
.A streamed HTTP/2
Request
.Builds a new
HttpRequest
.A duplicator that duplicates a
HttpRequest
into one or more HttpRequest
s,
which publish the same elements.Sets properties for building an
HttpRequest
.An
HttpRequest
that can have HttpObject
s written to it.A streamed HTTP/2
Response
.Builds a new
HttpResponse
.A duplicator that duplicates a
HttpResponse
into one or more HttpResponse
s,
which publish the same elements.A
RuntimeException
that is raised to send an HTTP response with the content specified
by a user.An
HttpResponse
that can have HttpObject
s written to it.Deprecated.
Use
ResponseEntity
instead.An HTTP/2
Service
.An interface that enables getting all the
Route
s where an HttpService
should be bound.HTTP response code and its description.
The class of HTTP status.
A
RuntimeException
that is raised to send a simplistic HTTP response with minimal content
by a Service
.A virtual file system that provides the files requested by
FileService
.A utility class which provides factory methods in order to easily create a
Predicate
of an
InetAddress
.A builder for creating a
ByteStreamMessage
that reads data from the InputStream
and publishes using HttpData
.Defines the IDs of internal
HttpService
s that should not be exposed to the external network.A collection of internal
HttpService
s and their Port
s.Client authentication failed (e.g., unknown client, no client authentication included, or
unsupported authentication method).
The provided authorization grant (e.g., authorization code, resource owner credentials) or
refresh token is invalid, expired, revoked, does not match the redirection URI used in the
authorization request, or was issued to another client.
An
InvalidResponseException
raised when a client received an invalid HttpResponse
.The request is missing a required parameter, includes an unsupported parameter value (other than
grant type), repeats a parameter, includes multiple credentials, utilizes more than one mechanism
for authenticating the client, or is otherwise malformed.
A
RuntimeException
raised when a client received an invalid response.An HTTP response that is not valid for the given request/response flow.
An
InvalidResponseException
raised when a client received a response with invalid headers.Indicates that a SAML request is not valid.
The requested scope is invalid, unknown, malformed, or exceeds the scope granted by the resource
owner.
Retrieves a Retrofit
Invocation
associated with a RequestLog
.A Java SPI (Service Provider Interface) for the default
Jackson
ObjectMapper
.A
RequestConverterFunction
which converts a JSON body of
the AggregatedHttpRequest
to an object using the default ObjectMapper
.A response converter implementation which creates an
HttpResponse
with
content-type: application/json; charset=utf-8
or content-type: application/json-seq
.An
HttpService
that dispatches its requests to a web application running in an embedded
Jetty.Builds a
JettyService
.Provides a way for users to add
ResponseAs
mappings to transform an aggregated response
given that the corresponding Predicate
is satisfied.A builder implementation for JSON
HeadersSanitizer
.A utility class which helps to create a JavaScript Object
Notation (JSON) Lines text from a content
Publisher
or Stream
.A builder implementation for
JsonLogFormatter
.A utility class which helps to create a JavaScript Object
Notation (JSON) Text Sequences from a content
Publisher
or Stream
.An
AccessLogWriter
that sends access logs to a Kafka backend.A builder class which creates a new
KeyStoreCredentialResolver
instance.A
BlockHoundIntegration
for the Fabric Kubernetes module.A
DynamicEndpointGroup
that fetches a node IP and a node port for each Pod from Kubernetes.A builder for creating a new
KubernetesEndpointGroup
.An interface that accepts item change listeners.
A variant of
AsyncCloseable
which allows a user to check whether the object is closed or to get
notified when closed.A
HealthChecker
which notifies its state change to its listeners.A root node representing a
Listener
.A snapshot of a
Listener
resource.A resource object for a
Listener
.Specifies an active local port of an Armeria server.
Specifies active ports of an Armeria server.
Builds a new
LoggingClient
.A
LoggingService
decorator for annotated HTTP services.Builds a new logging decorator.
A factory which creates a
LoggingService
decorator.The containing annotation type for
LoggingDecorator
.Builds a new
LoggingRpcClient
.Builds a new
LoggingService
.Log level.
Writes logs of a
RequestLog
.Builds a new
LogWriter
.LRU (Least Recently Used) cache
Map
.An
HttpService
that provides monitoring and management features.A map
TypeSignature
.Supported markup types in
Description
.Specifies a predicate which evaluates whether a request can be accepted by a service method.
The containing annotation type for
MatchesHeader
.Specifies a predicate which evaluates whether a request can be accepted by a service method.
The containing annotation type for
MatchesParam
.Represents an Internet Media Type
(also known as a MIME Type or Content Type).
String constants defined in
MediaType
class.A function used for determining the
MediaType
of a file based on its path.Creates a
MeterIdPrefix
from a RequestLog
.Transforms a
MeterIdPrefix
into another.Metadata about a function of a
Service
.Decorates an
HttpClient
to collect metrics into MeterRegistry
.Builds a
MetricCollectingClient
instance.Decorates an
RpcClient
to collect metrics into MeterRegistry
.Builds a
MetricCollectingRpcClient
instance.Decorates an
HttpService
to collect metrics into MeterRegistry
.Builds a
MetricCollectingService
instance.Interface used to configure a
MetricCollectingService
on the default Armeria server.MIME Parsing exception.
An
Extension
primarily for testing clients.Provides useful
MeterBinder
s to monitor various Armeria components.Provides utilities for accessing
MeterRegistry
.This contains the implementations of the custom Scalar types.
A reactive
Multipart
that represents
Multiple part messages.A file uploaded from a
Multipart
request.Specifies when to remove the temporary files created for multipart requests.
Utility methods to support multipart metadata handling.
A
RuntimeException
that is raised when attempted to access a null request or response content.Indicates the return values, parameters and fields are non-nullable by default.
A
MeterRegistry
which does not record any values.A
Subscriber
that discards all elements silently.Indicates the return values, parameters and fields are nullable.
A response converter implementation which creates an
HttpResponse
of HttpStatus.NO_CONTENT
when the specified result
is null
.The bearer token of OAuth 1.0a authentication.
Builds a new
OAuth1aToken
.Represents an OAuth 2.0 Access Token Grant flow to obtain Access Token.
A builder for
OAuth2AuthorizationGrant
which represents an OAuth 2.0 Access Token Grant flow.Decorates a
HttpClient
with an OAuth 2.0 Authorization Grant flow.Deprecated.
Deprecated.
An interface that represents an OAuth 2.0 request.
Deprecated.
Deprecated.
A functional interface to handle OAuth2 responses.
The bearer token of OAuth 2.0 authentication.
Defines a structure of the Token Introspection Response, as per
[RFC7662], Section 2.2.
Builds an instance of
OAuth2TokenDescriptor
.Determines whether a given
OAuth2Token
is authorized for the service registered in using OAuth 2.0
Token Introspection.Builds a
OAuth2TokenIntrospectionAuthorizer
instance.A helper class that allows handling optional validation of the OAuth 2 token within specific execution
context (e.g. to implement fine-grained access control).
A
ResponseConverterFunction
which converts the Observable
instance to a Flowable
first, then converts it to an HttpResponse
using the specified responseConverter
.A
ResponseConverterFunction
which converts the Observable
instance to a Flowable
first, then converts it to an HttpResponse
using the specified responseConverter
.Annotation for mapping
HttpMethod.OPTIONS
onto specific method.Specifies an order which is used to sort the annotated service methods.
Operating system.
Annotation for mapping a parameter of a request onto the following elements.
Annotation for mapping
HttpMethod.PATCH
onto specific method.Annotation for mapping dynamic web requests onto specific method.
Provides the setters for building a path and a query string.
Annotation that can be used on a class as a path prefix for all the
methods that handle http request.
The containing annotation type for
Path
.A builder for creating a
ByteStreamMessage
that reads data from the Path
and publishes
using HttpData
.Utility class that provides ways to create a pooled
Bytes
and manage its life cycle.Annotation for mapping
HttpMethod.POST
onto specific method.An
SSLException
raised before starting a TLS handshake.Specifies a media type which would be produced by the service method or class.
An alias for
@Produces(MediaTypeNames.APPLICATION_BINARY)
.An alias for
@Produces(MediaTypeNames.EVENT_STREAM)
and
@ResponseConverter(ServerSentEventResponseConverterFunction.class)
.The containing annotation type for
Produces
.An alias for
@Produces(MediaTypeNames.JSON_UTF_8)
.An alias for
@Produces(MediaTypeNames.JSON_SEQ)
.An alias for
@Produces(MediaTypeNames.OCTET_STREAM)
.An alias for
@Produces(MediaTypeNames.PROTOBUF)
.An alias for
@Produces(MediaTypeNames.PLAIN_TEXT_UTF_8)
.Deprecated.
Use
PrometheusExpositionService
in armeria-prometheus1
module instead.Exposes Prometheus metrics in
EXPOSITION FORMATS.
Deprecated.
Use
PrometheusExpositionServiceBuilder
in armeria-prometheus1
module instead.Builds a
PrometheusExpositionService
.Deprecated.
Use
PrometheusMeterRegistries
in armeria-prometheus1
module instead.Provides the convenient factory methods for
PrometheusMeterRegistry
.A
Properties
backed EndpointGroup
.Builds a
PropertiesEndpointGroup
.A
RequestConverterFunction
which converts a Protocol Buffers or JSON body of
the AggregatedHttpRequest
to an object.Provides a
ProtobufRequestConverterFunction
to annotated services.A
ResponseConverterFunction
which creates an HttpResponse
with
content-type: application/protobuf
or content-type: application/json; charset=utf-8
.Provides a
ProtobufResponseConverterFunction
to annotated services.A
RuntimeException
raised when a remote peer violated the current SessionProtocol
.An interface to provide source and destination addresses delivered from a proxy server.
Base configuration for proxy settings used by
ClientFactory
.Selects the
ProxyConfig
to use when connecting to a network
resource specified by the SessionProtocol
and Endpoint
parameter.The proxy protocol type.
Adapts a
Publisher
into a StreamMessage
.Annotation for mapping
HttpMethod.PUT
onto specific method.Immutable HTTP query parameters.
Builds a
QueryParams
.A
ThrottlingService
decorator for annotated HTTP services.A factory which creates a
ThrottlingService
decorator with a
ThrottlingStrategy.rateLimiting(double, String)
.The containing annotation type for
RateLimitingDecorator
.A request that has been made to a
MockWebServerExtension
.Configuration for
automatic redirection.
A builder for
RedirectConfig
.An
HttpService
that sends a redirect response such as "307 Temporary Redirect"
.A
RuntimeException
raised in
automatic redirection.A
RuntimeException
raised when a server set
HTTP/2 MAX_CONCURRENT_STREAMS
to 0, which means a client can't send anything.Regex based sanitizer.
A holder of releasable resource
ReleasableHolder
.A request.
Provides access to
RequestAttribute
s specified when sending a request.A
CancellationException
raised when a request is cancelled by the user.Utility class to keep
RequestContext
during RxJava operations.Utility class to keep
RequestContext
during RxJava operations.Tracing
context implemented with
RequestContext
.A builder of
RequestContextCurrentTraceContext
to enable tracing of an Armeria-based application.Exports the specified properties from current
RequestContext
to Map
.Builds a new
RequestContextExporter
.Utility class to keep
RequestContext
during
Reactor operations.The storage for storing
RequestContext
.Creates a new
RequestContextStorage
dynamically via Java SPI (Service Provider Interface).Wraps an existing
RequestContextStorage
.Wraps an existing
RequestContext
.Specifies a
RequestConverterFunction
class which converts an AggregatedHttpRequest
to
an object.Converts an
AggregatedHttpRequest
to an object.A
RequestConverterFunction
provider interface which creates a new
RequestConverterFunction
for converting an AggregatedHttpRequest
to an object of
the given type.The containing annotation type for
RequestConverter
.An entity of an HTTP request.
Immutable HTTP/2 headers for an
HttpRequest
.Builds a
RequestHeaders
.Provides the access to a
RequestLog
or RequestOnlyLog
, while ensuring the interested
RequestLogProperty
s are available.A
RuntimeException
raised when accessing a RequestLog
property that's not available yet.Updates a
RequestLog
with newly available information.A property of
RequestLog
, used for identifying properties that have been populated during request
processing.Provide the setters for building an
HttpMethod
and a request path.Specifies which element should be converted by
RequestConverterFunction
.A set of informational properties for request-side only, collected while consuming a
Request
.A
RequestOptions
for an HttpRequest
.A builder for creating a new
RequestOptions
.Provides the setters for building
RequestOptions
.Provides the setters for building an
HttpRequest
and RequestOptions
.Provides the access to request-scoped
MDC
properties.An HTTP request target, as defined in
Section 3.2, RFC 9112.
RequestTarget
form, as defined in
Section 3.2, RFC 9112.Annotation for request timeout.
A factory which creates a decorator that sets request timeout to current
ServiceRequestContext
.A
TimeoutException
raised when a request has not been received from a client within timeout.A
CircuitBreakerClientHandler
implementation for use with Resilience4j's CircuitBreaker
.A functional interface that represents a mapper factory, mapping a combination of host, method and path
to a
CircuitBreaker
using a CircuitBreakerRegistry
.Returns a
CircuitBreaker
instance from remote invocation parameters.Builder class for building a
Resilience4jCircuitBreakerMapping
based on a combination of host, method and path.A response stream or a holder of the future result value.
Transforms a response into another.
A
CancellationException
raised when a response is cancelled by the user.A special
CancellationException
that aborts an HttpRequest
after the corresponding
HttpResponse
is completed.Specifies a
ResponseConverterFunction
class which converts the result to HttpResponse
.Converts a
result
object to HttpResponse
.A
ResponseConverterFunction
provider interface which creates a new
ResponseConverterFunction
for converting an object of the given type and functions.The containing annotation type for
ResponseConverter
.An entity of an HTTP response.
Immutable HTTP/2 headers for an
HttpResponse
.Builds a
ResponseHeaders
.A
TimeoutException
raised when a response has not been received from a server within timeout.A client designed for calling RESTful APIs conveniently.
Prepares and executes a new
HttpRequest
for RestClient
.RESTEasy service implementing Armeria's
HttpService
.Builds
ResteasyService
.A
BlockHoundIntegration
for the retrofit2 module.Returns the default function for retrofit that creates a
MeterIdPrefix
with the specified name and
the Tag
s derived from the RequestLog
properties and Invocation
.Holds retry config used by a
RetryingClient
.Builds a
RetryConfig
.Returns a
RetryConfig
given the ClientRequestContext
.A
RetryDecision
that determines whether a RetryRule
retries with a Backoff
,
skips the current RetryRule
or no retries.An
HttpClient
decorator that handles failures of an invocation and retries HTTP requests.Builds a new
RetryingClient
or its decorator function.An
RpcClient
decorator that handles failures of an invocation and retries RPC requests.Builds a new
RetryingRpcClient
or its decorator function.Determines whether a failed request should be retried.
A builder for creating a new
RetryRule
.Determines whether a failed request should be retried using the content of a
Response
.A builder for creating a new
RetryRuleWithContent
.Route
maps from an incoming HTTP request to an HttpService
based on its path, method,
content type and accepted types.Builds a new
Route
.A value mapped by
Router
.The type of the path which was specified when a
Route
is created.Finds a mapping that matches a given
RoutingContext
.A snapshot of a
RouteConfiguration
resource.A resource object for a
RouteConfiguration
.Holds the parameters which are required to find a service available to handle the request.
The result returned by
Route.apply(RoutingContext, boolean)
.Builds a new
RoutingResult
.The type of
RoutingResult
.A routing status of an incoming HTTP request.
Sends an
RpcRequest
to a remote Endpoint
.An RPC
Request
.An RPC
Response
.An RPC
Service
.An interface that enables getting all the
Route
s where an RpcService
should be bound.Interface used to configure a scala type, data fetcher, directives, etc on the GraphQL service.
An
AutoCloseable
whose SafeCloseable.close()
method does not throw an exception.A configuration for an assertion consumer service of a service provider.
A builder which builds a
SamlAssertionConsumerConfig
.SAML binding protocols.
A SAML service URL and its binding protocol.
Indicates that an error occurred while processing a SAML request.
A configuration for an identity provider.
A builder which builds a
SamlIdentityProviderConfig
.A
SamlIdentityProviderConfig
selector for the request.SAML name ID formats.
SAML name ID format and its option.
An interface which generates and validates a request ID when transferring a SAML message between
a service provider and an identity provider.
A SAML service provider implementation.
A builder which builds a
SamlServiceProvider
.A callback which is invoked when a SAML single logout request is received.
Callbacks which are invoked to handle SAML messages exchanging with an identity provider.
A utility class which helps a user to easily handle a SAML message.
Sampler is responsible for deciding if a particular trace should be "sampled", i.e. whether the
overhead of tracing will occur and/or if a trace will be reported to the collection tier.
A pair of
SerializationFormat
and SessionProtocol
.An
Extension
that provides a temporary self-signed certificate.A
TestRule
that provides a temporary self-signed certificate.Serialization format of a remote procedure call and its reply.
Registers the
SerializationFormat
s dynamically via Java SPI (Service Provider Interface).A registration entry of a
SerializationFormat
.Listens to
ServerPort
s and delegates client requests to Service
s.Builds a new
Server
and its ServerConfig
.Directives for HTTP caching mechanisms in responses.
Creates a new
ServerCacheControl
using the builder pattern.Server
configuration.A Server that allows ability to reconfigure its service endpoints without having to restart the server.
Provides the error responses in case of unexpected exceptions or protocol errors.
Listens to life cycle events of a
Server
.A skeletal
ServerListener
implementation in order for a user to implement only the methods
what he or she really needs.Builds a new
ServerListener
.A class that holds metrics related server.
A pair of server-side bind address and
SessionProtocol
.An interface for the Server-Sent Events specification.
A builder which creates a
ServerSentEvent
instance.A response converter implementation which creates an
HttpResponse
with
content-type: text/event-stream
.A utility class which helps to create a Server-Sent Events
stream from a content
Publisher
or Stream
.A class that represents a service instance used by
Finagle ServerSets.
Builds a
ZooKeeperRegistrationSpec
for
Finagle ServerSets.A builder class for binding an
HttpService
fluently.A helper class that invokes the callback methods in
Service
.An
HttpService
configuration.Provides the error responses in case of unexpected exceptions.
Metadata about a
Service
.Annotation for service name that is often used as a meter tag or distributed trace's span name.
Generates the default name of a
Service
from its ServiceRequestContext
.A
Observation.Context
which may be used in conjunction with ObservationService
to implement custom ObservationConvention
s or ObservationHandler
s.An annotation used to configure
ServiceOptions
of an HttpService
.Options for configuring an
HttpService
.Creates a new
ServiceOptions
with the specified parameters.Provides information about an invocation and related utilities.
Builds a new
ServiceRequestContext
.Captures the
ServiceRequestContext
s.Wraps an existing
ServiceRequestContext
.The specification of one or more
Service
s that provides their ServiceInfo
s and
DescriptiveTypeInfo
s.Session-level protocol that provides facilities such as framing and flow control.
Keeps the recent
SessionProtocol
negotiation failures.An exception triggered when failed to negotiate the desired
SessionProtocol
with a server.A simple
ListenableHealthChecker
whose state can be set by a caller.Supplies a cached value which can be useful for the below case.
A utility class for adding a task with an
AutoCloseable
on shutdown.A function that accepts one signal and produces the length of the signal.
Decorates a
Client
.Decorates an
HttpClient
.An
HttpService
that decorates another HttpService
.Decorates an
RpcClient
.An
RpcService
that decorates another RpcService
.A snapshot of the resource.
A watcher implementation which waits for updates on an xDS snapshot.
SOCKS4 proxy configuration.
SOCKS5 proxy configuration.
An
HttpMessage
which splits a stream of HttpObject
s into payloads and HTTP trailers.An
HttpRequest
which splits a stream of HttpObject
s into HTTP headers and payloads.An
HttpResponse
which splits a stream of HttpObject
s into HTTP headers and payloads.Injects dependencies in annotations using the
BeanFactory
.Simple server-independent abstraction for SSL configuration.
An element in a stack trace, based on the Java type of the same name.
An element in a stack trace, based on the Java type of the same name.
Provides asynchronous start-stop life cycle support.
A
RuntimeException
reconstructed from debug information in a failed gRPC
response, containing information about the cause of the exception at the server
side.An annotation which specifies a default HTTP status code of a response produced by an annotated HTTP service.
A handler that converts specific error
HttpStatus
s to a Throwable
to be propagated
downstream instead of the response.Utility to escape status messages (e.g., error messages) for saving to ascii headers.
Deprecated.
Use
StreamDecoder
instead.An interface for objects that apply HTTP content decoding to incoming
HttpData
.Decodes a stream of data to N objects.
Deprecated.
Use
StreamDecoderFactory
instead.An interface that constructs a new
StreamDecoder
for a given Content-Encoding header value.An input of
StreamDecoder
which is used to read a stream of objects.An output of
StreamDecoder
which holds the decoded data.A skeletal
HttpFile
that simplifies the streaming of potentially large content.A duplicator that duplicates a
StreamMessage
into one or more StreamMessage
s,
which publish the same elements.A utility class for
StreamMessage
.Wraps a
StreamMessage
and forwards its method invocations to delegate
.Produces the objects to be published by a
StreamMessage
.A
ResponseConverterFunction
which creates an HttpResponse
when:
the result
is an instance of CharSequence
the "content-type"
of the ResponseHeaders
is MediaType.ANY_TEXT_TYPE
Note that this ResponseConverterFunction
is applied to an annotated service by default,
so you don't have to specify this converter explicitly.Metadata about a struct type.
Options used when subscribing to a
StreamMessage
.Provides utilities for accessing the information about the current system and process.
A utility class to format things as a
String
with ease.A builder implementation for Text
HeadersSanitizer
.A builder implementation for
TextLogFormatter
.Provides a builder for
ThreadFactory
.Builds a new
ThreadFactory
.An
RpcService
that handles a Thrift RpcRequest
.Creates a new Thrift client that connects to the specified
URI
using the builder pattern.ClientOption
s to control Thrift-specific behavior.Creates a new Thrift client that connects to a
URI
or an EndpointGroup
.A
CompletableFuture
that can be passed in as an AsyncMethodCallback
when making an asynchronous client-side Thrift RPC.Jackson
Module
for Thrift types.A
ListenableFuture
that can be passed in as an AsyncMethodCallback
when making an asynchronous client-side Thrift RPC.A container of a Thrift message produced by Apache Thrift.
Provides a set of well-known
TProtocolFactory
s.SPI Provider for links from
SerializationFormat
to TProtocolFactory
.Pair of
SerializationFormat
and TProtocolFactory
.A container of a Thrift reply or exception object (
TBase
or TApplicationException
) and
its header (TMessage
).Provides Thrift-related
SerializationFormat
instances and their TProtocolFactory
s.The information about a Thrift service served by
THttpService
or ThriftCallService
.A callback which is invoked to handle accepted (successful) requests indicated by
ThrottlingStrategy
.A RateLimit Header Scheme for HTTP.
A callback which is invoked to handle rejected (failure) requests indicated by
ThrottlingStrategy
.Decorates an RPC
Service
to throttle incoming requests.Builds a new
ThrottlingRpcService
.Decorates an
HttpService
to throttle incoming requests.Builds a new
ThrottlingService
.Determines whether a request should be throttled.
An exception that was thrown by some code, based on the Java type of the same name.
An exception that was thrown by some code, based on the Java type of the same name.
A generic Thrift-over-HTTP client.
An
HttpService
that handles a Thrift call.A fluent builder to build an instance of
THttpService
.A time source; returns a time value representing the number of nanoseconds elapsed since some
fixed but arbitrary point in time.
A
RuntimeException
raised when a requested invocation does not complete before its deadline.The timeout mode.
Tls engine types.
Sets properties for TLS or SSL.
Stores configuration of the Token-Bucket algorithm, comprised of multiple limits.
Builds a
TokenBucket
instance.A
ThrottlingStrategy
that provides a throttling strategy based on Token-Bucket algorithm.Builds
TokenBucketThrottlingStrategy
.An OAuth 2.0 request for token operations such as
OAuth 2.0 Token Revocation and
OAuth 2.0 Token Introspection
A common token request exception type.
Implements Token Revocation request/response flow,
as per [RFC7009].
Builds
TokenRevocation
.An
HttpService
that dispatches its requests to a web application running in an embedded
Tomcat.Builds a
TomcatService
.A
RuntimeException
that is raised when configuring or starting an embedded Tomcat fails.A
RuntimeException
raised when the number of pending acquisitions exceeds the
ConcurrencyLimitBuilder.maxPendingAcquisitions(int)
.An exception indicating that
automatic redirection exceeds the
maximum limit number.
Annotation for mapping
HttpMethod.TRACE
onto specific method.Manually propagates a
TraceContext
to a BraveClient
.Prepares and executes a new
HttpRequest
for a WebClient
or BlockingWebClient
, and
transforms an HttpResponse
into the T
type object.An
HttpService
that handles transient requests, for example, health check requests.An
RpcService
that handles transient requests, for example, health check requests.A
Service
that handles transient requests, for example, health check requests.Builds a
TransientService
.Specifies which features should be enabled for a
TransientService
.Native transport types.
The
TProtocolFactory
that creates a TTextProtocol
.Type signature of a method parameter, a method return value or a struct/exception field.
Represents the different type that is used for
DocService
.A
UnaryGrpcClient
can be used to make requests to a gRPC server without depending on gRPC stubs.The authenticated client is not authorized to use this authorization grant type.
An exception indicating that the host component of the redirection URI
is not allowed to redirect.
An exception indicating that the session protocol of the redirection URI
is not allowed to redirect.
Error handler which maps a gRPC response to an
HttpResponse
.Constructs a
UnframedGrpcErrorHandler
to handle unframed gRPC errors.The types of responses that can be sent when handling errors in an unframed gRPC service.
A
CompletableFuture
which prevents the caller from completing it.A
RuntimeException
raised when it is certain that a request has not been handled by a server and
thus can be retried safely.Indicates the API of the target is not mature enough to guarantee the compatibility between releases.
The authorization grant type is not supported by the authorization server.
A response
Content-Type
header does not match the expected type.A response type in not supported by the given request/response flow.
The authorization server does not support the revocation of the presented token type.
Provides a way to unwrap an object in decorator pattern, similar to down-casting in an inheritance pattern.
A base class for implementing a user's entry point for sending a
Request
.Retrieves the version information of available Armeria artifacts.
A builder class for binding an
HttpService
to a virtual host fluently.Builds a new
VirtualHost
.A
VirtualHostContextPathAnnotatedServiceConfigSetters
builder which configures
an AnnotatedService
under a set of context paths.A builder class for binding a
decorator
to a Route
fluently under a set of context paths.A builder class for binding an
HttpService
fluently.Builds
ServiceConfig
s for a VirtualHostBuilder
.A builder class for binding a
decorator
to a Route
fluently.A builder class for binding an
HttpService
fluently.An asynchronous web client.
Creates a new web client that connects to the specified
URI
using the builder pattern.Prepares and executes a new
HttpRequest
for WebClient
.A
StreamMessage
that publishes WebSocketFrame
s.A WebSocket client.
Builds a
WebSocketClient
.An
InvalidResponseException
raised when a WebSocketClient
client received a response with
invalid headers during the handshake.WebSocket Defined Status Codes.
A
WebSocketFrame
to send data to the peer.Represents the
WebSocketFrame
types.Implement this interface to handle incoming
WebSocketFrame
s from the peer and
send WebSocketFrame
s to the peer.A WebSocket protocol handler for
WebSocketService
.A
ProtocolViolationException
that is raised when failing to decode a WebSocketFrame
.An
HttpService
that supports
The WebSocket Protocol.Builds a
WebSocketService
.Implement this interface to handle incoming
WebSocketFrame
s from the peer and
send WebSocketFrame
s to the peer.A WebSocket session that is created after
WebSocketClient.connect(String)
succeeds.The result of a WebSocket upgrade.
A
WebSocket
that you can write WebSocketFrame
s to it.Builds a weight ramping up
EndpointSelectionStrategy
which ramps the weight of newly added
Endpoint
s.A
TimeoutException
raised when a client failed to send a request to the wire within timeout.An
XdsBootstrap
encapsulates all logic to communicate with control plane servers
to fetch xDS resources locally.Provides a simple
EndpointGroup
which listens to an xDS cluster to select endpoints.An object for xDS resources.
A representation of the supported xDS types.
A discovery specification for
ZooKeeperEndpointGroup
.A ZooKeeper-based
EndpointGroup
implementation.Builds a
ZooKeeperEndpointGroup
.A registration specification for
ZooKeeperUpdatingListener
.Builds a new
ZooKeeperUpdatingListener
, which registers the server to a ZooKeeper cluster.
ClientAuthentication
instead.