All Classes

Class Description
AbortedStreamException
A RuntimeException that is raised to signal a Subscriber that the StreamMessage it subscribed to has been aborted by StreamMessage.abort().
AbstractAllOrEachExtension
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.
AbstractArmeriaAutoConfiguration
Abstract class for implementing ArmeriaAutoConfiguration of boot2-autoconfigure module and ArmeriaSpringBoot1AutoConfiguration of boot1-autoconfigure module.
AbstractArmeriaBeanPostProcessor
Abstract class for implementing ArmeriaBeanPostProcessor of boot2-autoconfigure module and ArmeriaSpringBoot1BeanPostProcessor of boot1-autoconfigure module.
AbstractAuthorizerWithHandlers<T>
Provides base implementation for an Authorizer that defines custom AuthSuccessHandler/AuthFailureHandlers.
AbstractBackoff
A skeletal Backoff implementation.
AbstractBlockingHttpVfs
A skeletal HttpVfs implementation for accessing file system with blocking I/O.
AbstractCircuitBreakerClient<I extends Request,​O extends Response>
A Client decorator that handles failures of remote invocation based on circuit breaker pattern.
AbstractCircuitBreakerClientBuilder<O extends Response>
A skeletal builder implementation that builds a new AbstractCircuitBreakerClient or its decorator function.
AbstractClientOptionsBuilder
A skeletal builder implementation for ClientOptions.
AbstractConcurrencyLimitingClient<I extends Request,​O extends Response>
An abstract Client decorator that limits the concurrent number of active requests.
AbstractCuratorFrameworkBuilder
A skeletal builder implementation for CuratorFramework.
AbstractEndpointSelector
A skeletal EndpointSelector implementation.
AbstractHealthCheckedEndpointGroupBuilder
A skeletal builder implementation for creating a new HealthCheckedEndpointGroup.
AbstractHttpFile
A skeletal HttpFile implementation.
AbstractHttpFileBuilder
A skeletal builder class which helps easier implementation of HttpFileBuilder or AggregatedHttpFileBuilder.
AbstractHttpRequestBuilder
Builds a new HttpRequest.
AbstractHttpService
A skeletal HttpService for easier HTTP service implementation.
AbstractHttpVfs
A skeletal HttpVfs implementation.
AbstractListenable<T>
A skeletal Listenable implementation.
AbstractMetricCollectingBuilder
Builds an implementing class of AbstractMetricCollectingBuilder instance.
AbstractOption<T extends AbstractOption<T,​U,​V>,​U extends AbstractOptionValue<U,​T,​V>,​V>
A configuration option.
AbstractOption.Factory<T extends AbstractOption<T,​U,​V>,​U extends AbstractOptionValue<U,​T,​V>,​V>
Creates a new option instance.
AbstractOptions<T extends AbstractOption<T,​U,​Object>,​U extends AbstractOptionValue<U,​T,​Object>>
A set of configuration options and their respective values.
AbstractOptionValue<T extends AbstractOptionValue<T,​U,​V>,​U extends AbstractOption<U,​T,​V>,​V>
A holder of a value of an AbstractOption.
AbstractRequestContextBuilder
Provides the information required for building a RequestContext.
AbstractRetryingClient<I extends Request,​O extends Response>
A Client decorator that handles failures of remote invocation and retries requests.
AbstractRetryingClientBuilder<O extends Response>
Builds a new AbstractRetryingClient or its decorator function.
AbstractRuleBuilder
AbstractRuleWithContentBuilder<T extends Response>
A skeletal builder implementation for RetryRuleWithContent and CircuitBreakerRuleWithContent.
AbstractThrottlingService<I extends Request,​O extends Response>
Decorates a Service to throttle incoming requests.
AbstractUnaryGrpcService
An AbstractUnaryGrpcService can be used to implement a gRPC service without depending on gRPC stubs.
AbstractUnsafeUnaryGrpcService
An AbstractUnsafeUnaryGrpcService can be used to implement a gRPC service without depending on gRPC stubs.
AbstractUnwrappable<T extends Unwrappable>
Skeletal Unwrappable implementation.
AbstractWebClientBuilder
A skeletal builder implementation for WebClient.
AccessLogWriter
Consumes the RequestLogs produced by a Service, usually for logging purpose.
AdditionalHeader
Annotation for an additional HTTP header.
AdditionalHeaders
The containing annotation type for AdditionalHeader.
AdditionalTrailer
Annotation for an additional HTTP trailer.
AdditionalTrailers
The containing annotation type for AdditionalTrailer.
AggregatedBodyPart
A complete body part whose headers and content are readily available.
AggregatedHttpFile
A complete HTTP file whose attributes and content are readily available.
AggregatedHttpFileBuilder
Builds an AggregatedHttpFile from an HttpData.
AggregatedHttpObject
A complete HTTP headers and content that are readily available.
AggregatedHttpRequest
A complete HTTP request whose content is readily available as a single HttpData.
AggregatedHttpResponse
A complete HTTP response whose content is readily available as a single HttpData.
AggregatedMultipart
A complete multipart whose body parts are readily available.
AnnotatedServiceBindingBuilder
A builder class for binding an HttpService fluently.
AppRootFinder
A utility that looks for the Path to the JAR, WAR or directory where a Class is located at.
ArmeriaAutoConfiguration
Spring Boot Configuration that provides Armeria integration.
ArmeriaBeanPostProcessor
BeanPostProcessor implementation that autowires annotated fields, setter methods, and arbitrary config methods.
ArmeriaBeanPostProcessorConfiguration
Spring Boot Configuration that provides Armeria integration.
ArmeriaBundle<C extends Configuration>
A Dropwizard ConfiguredBundle that routes requests through an Armeria Server rather than the default Jetty server.
ArmeriaClientAutoConfiguration
An auto-configuration for Armeria-based WebClient.
ArmeriaClientConfigurator
A configurator to configure an WebClientBuilder for an ArmeriaClientHttpConnector.
ArmeriaJaxrsClientEngine
An implementation of AsyncClientHttpEngine based on Armeria WebClient.
ArmeriaMessageDeframer
A deframer of messages transported in the gRPC wire format.
ArmeriaMessageFramer
A framer of messages for transport with the gRPC wire protocol.
ArmeriaReactiveWebServerFactory
A ReactiveWebServerFactory which is used to create a new ArmeriaWebServer.
ArmeriaReactiveWebServerFactoryAutoConfiguration
An auto-configuration for a reactive web server.
ArmeriaResteasyClientBuilder
An optional helper class to build ResteasyClient using ResteasyClientBuilder interface as below.
ArmeriaRetrofit
Provides various ways to create a Retrofit which uses WebClient for sending requests.
ArmeriaRetrofitBuilder
A builder that creates a Retrofit which uses WebClient for sending requests.
ArmeriaServerConfigurator
Interface used to configure a service on the default armeria server.
ArmeriaSettings
Settings for armeria servers.
ArmeriaSettings.Compression
Configurations for the HTTP content encoding.
ArmeriaSettings.Port
Port and protocol settings.
ArmeriaSpringActuatorAutoConfiguration
A Configuration to enable actuator endpoints on an Armeria server.
ArmeriaStatusException
An Exception that contains enough information to convert it to a gRPC status.
AsyncCloseable
An object that may hold resources until it is closed.
AsyncCloseableSupport
Provides support for implementing AsyncCloseable or ListenableAsyncCloseable.
AsyncMethodCallbacks
A utility class that bridges the gap between CompletionStage and AsyncMethodCallback.
AuthFailureHandler
A callback which is invoked to handle an authorization failure indicated by Authorizer.
AuthorizationStatus
Provides a status of the request authorization operation, optionally combined with AuthSuccessHandler and AuthFailureHandler to facilitate custom status handling.
Authorizer<T>
Determines whether a given data is authorized for the service registered in.
AuthService
Decorates an HttpService to provide HTTP authorization functionality.
AuthServiceBuilder
Builds a new AuthService.
AuthSuccessHandler
A callback which is invoked to handle an authorization success indicated by Authorizer.
AuthTokenExtractors
A utility class that provides singleton instances of authorization token extractor functions.
Backoff
Controls back off between attempts in a single retry operation.
BackoffWrapper
Wraps an existing Backoff.
BandwidthLimit
Stores configurations of a single Token-Bucket bandwidth limit.
BasicToken
Blocking
Specifies that the annotated service method must be invoked from the blocking task executor instead of an event loop thread.
BodyPart
A body part entity.
BodyPartBuilder
A builder class for creating BodyPart instances.
BraveClient
Decorates an HttpClient to trace outbound HttpRequests using Brave.
BraveService
Decorates an HttpService to trace inbound HttpRequests using Brave.
BuiltInProperty
A built-in property exported by RequestContextExporter.
ByteArrayRequestConverterFunction
A RequestConverterFunction which converts a binary body of the AggregatedHttpRequest to one of byte[] or HttpData depending on the expectedResultType.
ByteArrayResponseConverterFunction
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.
ByteBufAccessMode
Specifies the way a ByteBuf is retrieved from an HttpData.
CacheControl
Directives for HTTP caching mechanisms in requests or responses.
CancellationException
A RuntimeException raised when a requested invocation is forced to stop before its completion.
CancelledSubscriptionException
A RuntimeException that is raised to notify StreamMessage.whenComplete() when a Subscriber has cancelled its Subscription.
ChainedCorsPolicyBuilder
Builds a new CorsPolicy.
CircuitBreaker
A circuit breaker, which tracks the number of success/failure requests and detects a remote service failure.
CircuitBreakerBuilder
Builds a CircuitBreaker instance using builder pattern.
CircuitBreakerClient
An HttpClient decorator that handles failures of HTTP requests based on circuit breaker pattern.
CircuitBreakerClientBuilder
Builds a new CircuitBreakerClient or its decorator function.
CircuitBreakerDecision
CircuitBreakerFactory
A functional interface that represents a mapper factory, mapping a combination of host, method and path to a CircuitBreaker.
CircuitBreakerListener
The listener interface for receiving CircuitBreaker events.
CircuitBreakerListenerAdapter
A skeletal CircuitBreakerListener implementation in order for a user to implement only the methods what he or she really needs.
CircuitBreakerMapping
Returns a CircuitBreaker instance from remote invocation parameters.
CircuitBreakerMappingBuilder
Builder class for building a CircuitBreakerMapping based on a combination of host, method and path.
CircuitBreakerRpcClient
An RpcClient decorator that handles failures of RPC remote invocation based on circuit breaker pattern.
CircuitBreakerRpcClientBuilder
Builds a new CircuitBreakerRpcClient or its decorator function.
CircuitBreakerRule
Determines whether a Response should be reported as a success or failure to a CircuitBreaker.
CircuitBreakerRuleBuilder
A builder for creating a new CircuitBreakerRule.
CircuitBreakerRuleWithContent<T extends Response>
Determines whether a Response should be reported as a success or failure to a CircuitBreaker using the content of the Response.
CircuitBreakerRuleWithContentBuilder<T extends Response>
A builder for creating a new CircuitBreakerRuleWithContent.
CircuitState
Defines the states of circuit breaker.
Client<I extends Request,​O extends Response>
Sends a Request to a remote Endpoint.
ClientAddressSource
A source which is used to get a client address.
ClientAuthorization
Provides client authorization for the OAuth 2.0 requests, as per [RFC6749], Section 2.3.
ClientBuilder
Creates a new client that connects to the specified URI using the builder pattern.
ClientBuilderParams
Provides the construction parameters of a client.
ClientCacheControl
Directives for HTTP caching mechanisms in requests.
ClientCacheControlBuilder
Creates a new ClientCacheControl using the builder pattern.
ClientConnectionTimings
A holder class which has the timing information about a connection attempt before a client sends a Request.
ClientConnectionTimingsBuilder
ClientDecoration
A set of Functions that transforms a Client into another.
ClientDecorationBuilder
Creates a new ClientDecoration using the builder pattern.
ClientFactory
Creates and manages clients.
ClientFactoryBuilder
Builds a new ClientFactory.
ClientFactoryOption<T>
A ClientFactory option.
ClientFactoryOptions
A set of ClientFactoryOptions and their respective values.
ClientFactoryOptionValue<T>
A value of a ClientFactoryOption.
ClientFactoryProvider
Creates a new ClientFactory dynamically via Java SPI (Service Provider Interface).
ClientOption<T>
A client option.
ClientOptions
A set of ClientOptions and their respective values.
ClientOptionsBuilder
Creates a new ClientOptions using the builder pattern.
ClientOptionValue<T>
A value of a ClientOption.
ClientRequestContext
Provides information about a Request, its Response and its related utilities.
ClientRequestContextBuilder
Builds a new ClientRequestContext.
ClientRequestContextCaptor
Captures the ClientRequestContexts created by the current thread.
ClientRequestContextWrapper
Wraps an existing ClientRequestContext.
Clients
Creates a new client that connects to a specified URI.
ClosedSessionException
A RuntimeException raised when the connection to the remote peer has been closed unexpectedly.
ClosedStreamException
A RuntimeException that is raised when a StreamMessage has been closed unexpectedly.
CommonPools
Provides the common shared thread pools and EventLoopGroups which is used when not overridden.
CompletableRpcResponse
An RpcResponse implementation which is initially incomplete and can be completed later.
CompletionActions
Provides the common actions that are useful when handling a CompletionStage.
CompositeException
Represents an exception that is a composite of one or more other exceptions.
Compressor
Represents a message compressor.
ConcurrencyLimitingClient
An HttpClient decorator that limits the concurrent number of active HTTP requests.
ConnectionPoolListener
Listens to the client connection pool events.
ConnectionPoolListenerAdapter
A skeletal ConnectionPoolListener implementation in order for a user to implement only the methods what he or she really needs.
ConnectionPoolListenerWrapper
ConnectProxyConfig
CONNECT proxy configuration.
ConsulConfigSetters
Sets properties for building a Consul client.
ConsulEndpointGroup
A Consul-based EndpointGroup implementation that retrieves the list of Endpoints from Consul using Consul's HTTP API and updates the Endpoints periodically.
ConsulEndpointGroupBuilder
A builder class for ConsulEndpointGroup.
ConsulUpdatingListener
A ServerListener which registers the current Server to Consul.
ConsulUpdatingListenerBuilder
Builds a new ConsulUpdatingListener, which registers the server to Consul cluster.
Consumes
Specifies a media type which would be consumed by the service method or class.
ConsumesBinary
An alias for @Consumes(MediaTypeNames.APPLICATION_BINARY).
ConsumesGroup
The containing annotation type for Consumes.
ConsumesJson
An alias for @Consumes(MediaTypeNames.JSON).
ConsumesOctetStream
An alias for @Consumes(MediaTypeNames.OCTET_STREAM).
ConsumesProtobuf
An alias for @Consumes(MediaTypeNames.PROTOBUF).
ConsumesText
An alias for @Consumes(MediaTypeNames.PLAIN_TEXT_UTF_8).
ContentDisposition
Representation of the Content-Disposition type and parameters as defined in RFC 6266.
ContentDispositionBuilder
A builder class for creating ContentDisposition.
ContentPreviewer
Produces the preview of RequestLog.
ContentPreviewerFactory
A factory creating a ContentPreviewer.
ContentPreviewerFactoryBuilder
A builder which builds a ContentPreviewerFactory.
ContentPreviewingClient
Decorates an HttpClient to preview the content of Requests and Responses.
ContentPreviewingService
Decorates an HttpService to preview the content of Requests and Responses.
ContentTooLargeException
A RuntimeException raised when the length of request or response content exceeds its limit.
ContextAwareEventLoop
A delegating EventLoop that sets the RequestContext before executing any submitted tasks.
ContextAwareScheduledExecutorService
A delegating ScheduledExecutorService that sets the RequestContext before executing any submitted tasks.
ContextHolder
A holder of RequestContext.
Cookie
An interface defining an HTTP cookie.
CookieBuilder
Builds a Cookie.
CookieClient
Decorates an HttpClient to set cookies to Cookie header of outgoing HttpRequest and store cookies from Set-Cookie headers of incoming HttpResponse.
CookieJar
A Cookie container for a client.
CookiePolicy
Specifies how CookieJar should accept new Cookie.
Cookies
An immutable Set of Cookies.
CookieState
The possible states of a Cookie in a CookieJar.
CoroutineContextProvider
Returns a CoroutineContext from a given ServiceRequestContext.
CoroutineContexts
Configures a coroutine context for annotated services and Kotlin suspending functions.
CoroutineContextService
Decorates an HttpService to configure the coroutine context which is used as an initial context of annotated services' suspending functions.
CorsConfig
CorsDecorator
A CorsService decorator for annotated HTTP services.
CorsDecoratorFactoryFunction
A factory which creates a CorsService decorator when only one CorsDecorator is added.
CorsDecorators
The containing annotation type for CorsDecorator.
CorsDecoratorsFactoryFunction
A factory which creates a CorsService decorator when two or more CorsDecorators are added.
CorsPolicy
Contains information of the CORS policy with the specified origins.
CorsPolicyBuilder
Builds a new CorsPolicy.
CorsService
Decorates an HttpService to add the Cross-Origin Resource Sharing (CORS) support.
CorsServiceBuilder
Builds a new CorsService or its decorator function.
CuratorDiscoverySpecBuilder
CuratorRegistrationSpecBuilder
DataBufferFactoryWrapperConfiguration
A configuration class which creates an DataBufferFactoryWrapper.
DecodingClient
A DecoratingClient that requests and decodes HTTP encoding (e.g., gzip) that has been applied to the content of an HttpResponse.
DecodingClientBuilder
A builder class for DecodingClient.
DecodingService
A DecoratingService that requests and decodes HTTP encoding (e.g., gzip) that has been applied to the content of an HttpRequest.
Decompressor
Represents a message decompressor.
DecoratingClient<T_I extends Request,​T_O extends Response,​R_I extends Request,​R_O extends Response>
Decorates a Client.
DecoratingClientFactory
A ClientFactory that delegates the creation of Clients to another ClientFactory.
DecoratingHttpClientFunction
A functional interface that enables building a SimpleDecoratingHttpClient with ClientBuilder.decorator(DecoratingHttpClientFunction).
DecoratingHttpServiceFunction
A functional interface that enables building a SimpleDecoratingHttpService with HttpService.decorate(DecoratingHttpServiceFunction).
DecoratingRpcClientFunction
A functional interface that enables building a SimpleDecoratingRpcClient with ClientBuilder.rpcDecorator(DecoratingRpcClientFunction).
DecoratingRpcServiceFunction
A functional interface that enables building a SimpleDecoratingRpcService with RpcService.decorate(DecoratingRpcServiceFunction).
DecoratingService<T_I extends Request,​T_O extends Response,​R_I extends Request,​R_O extends Response>
A Service that decorates another Service.
DecoratingServiceBindingBuilder
A builder class for binding a decorator with Route fluently.
Decorator
Specifies a DecoratingHttpServiceFunction class which handles an HttpRequest before invoking an annotated service method.
DecoratorFactory
Specifies a DecoratorFactoryFunction class which is a factory to create a decorator.
DecoratorFactoryFunction<T extends Annotation>
A decorator factory which is used for a user-defined decorator annotation.
Decorators
The containing annotation type for Decorator.
Default
Specifies the default value of an optional parameter.
DefaultClientRequestContext
Default ClientRequestContext implementation.
DefaultServiceRequestContext
Default ServiceRequestContext implementation.
DefaultStreamMessage<T>
A StreamMessage which buffers the elements to be signaled into a Queue.
DefaultStreamMessageDuplicator<T>
A default duplicator.
DeferredStreamMessage<T>
A StreamMessage whose stream is published later by another StreamMessage.
DeframedMessage
A deframed message.
Delete
Annotation for mapping HttpMethod.DELETE onto specific method.
Description
An annotation used in annotated HTTP service.
DirectProxyConfig
Represents a direct connection without a proxy.
DnsAddressEndpointGroup
DynamicEndpointGroup which resolves targets using DNS address queries (A and AAAA).
DnsAddressEndpointGroupBuilder
Builds a new DnsAddressEndpointGroup that sources its Endpoint list from the A or AAAA DNS records of a certain hostname.
DnsResolverGroupBuilder
Builds an AddressResolverGroup which builds AddressResolvers that update DNS caches automatically.
DnsServiceEndpointGroup
DynamicEndpointGroup which resolves targets using DNS SRV records.
DnsServiceEndpointGroupBuilder
Builds a new DnsServiceEndpointGroup that sources its Endpoint list from the SRV DNS records of a certain hostname.
DnsTextEndpointGroup
DynamicEndpointGroup which resolves targets using DNS TXT records.
DnsTextEndpointGroupBuilder
Builds a new DnsTextEndpointGroup that sources its Endpoint list from the TXT DNS records of a certain hostname.
DnsTimeoutException
A TimeoutException raised when a response has not been received from a DNS server within timeout.
DocService
An HttpService that provides information about the Services running in a Server.
DocServiceBuilder
Builds a new DocService.
DocServiceConfigurator
Configures a DocService built by Armeria auto configuration.
DocServiceFilter
A filter which includes or excludes service methods when building a DocService.
DocServicePlugin
Generates the ServiceSpecifications of the supported Services.
DocStringExtractor
A supporting base class for implementing the standard pattern of extracting docstrings from arbitrary files in a particular classpath location.
DocumentationProcessor
Processor that creates a properties file based on the JavaDoc/KDoc description of parameters for interfaces.
DropwizardMeterRegistries
Provides the convenient factory methods for DropwizardMeterRegistry with more sensible defaults for NamingConvention and HierarchicalNameMapper.
DynamicEndpointGroup
A dynamic EndpointGroup.
EmptyEndpointGroupException
An EndpointGroupException raised when the resolution of an EndpointGroup fails because there are no Endpoints in the EndpointGroup.
EmptyFixedStreamMessage<T>
A FixedStreamMessage that publishes no objects, just a close event.
EncodingService
Decorates an HttpService to apply HTTP encoding (e.g., gzip) to an HttpService.
EncodingServiceBuilder
Builds a new EncodingService or its decorator function.
Endpoint
A remote endpoint that refers to a single host.
EndpointGroup
A list of Endpoints.
EndpointGroupException
A RuntimeException raised when the resolution of an EndpointGroup fails.
EndpointInfo
Metadata about the endpoints exposed by a Service.
EndpointInfoBuilder
Creates a new EndpointInfo using the builder pattern.
EndpointSelectionStrategy
Endpoint selection strategy that creates a EndpointSelector.
EndpointSelector
Selects an Endpoint from an EndpointGroup.
EndpointWeightTransition
Computes the weight of the given Endpoint using the given currentStep and totalSteps.
EnumInfo
Metadata about an enum type.
EnumValueInfo
Metadata about an enum value.
EurekaEndpointGroup
A Eureka-based EndpointGroup implementation.
EurekaEndpointGroupBuilder
EurekaUpdatingListener
A ServerListener which registers the current Server to Eureka.
EurekaUpdatingListenerBuilder
Builds a EurekaUpdatingListener, which registers the server to Eureka.
EventCount
An immutable object that stores the count of events.
EventLoopCheckingFuture<T>
A CompletableFuture that warns the user if they call a method that blocks the event loop.
EventLoopExtension
An Extension that provides an EventLoopGroup.
EventLoopGroupExtension
An Extension that provides an EventLoopGroup.
EventLoopGroupRule
A TestRule that provides an EventLoopGroup.
EventLoopGroups
Provides methods that are useful for creating an EventLoopGroup.
EventLoopRule
A TestRule that provides an EventLoopGroup.
EventLoopScheduler
A scheduler which is responsible for assigning an EventLoop to handle a connection to the specified Endpoint.
ExceptionHandler
Specifies an ExceptionHandlerFunction class which handles exceptions throwing from an annotated service method.
ExceptionHandler
ExceptionHandlerFunction
An interface for exception handler.
ExceptionHandlers
The containing annotation type for ExceptionHandler.
ExceptionInfo
Metadata about an exception type.
Exceptions
Provides methods that are useful for handling exceptions.
ExceptionVerbosity
The verbosity of exceptions logged by annotated HTTP services.
ExportGroup
Holds a set of ExportGroupBuilder.ExportEntrys.
ExportGroupBuilder
Builds a new ExportGroup.
ExportGroupConfig
Bridge class for Logback configuration.
FailFastException
An exception indicating that a request has been failed by circuit breaker.
FallthroughException
A RuntimeException raised for falling through to the next something.
FieldInfo
Metadata about a field of a struct or an exception.
FieldInfoBuilder
Creates a new FieldInfo using the builder pattern.
FieldLocation
The location of a field.
FieldRequirement
The requirement level of a field.
FileService
An HttpService that serves static files from a file system.
FileServiceBuilder
Builds a new FileService and its FileServiceConfig.
FileServiceConfig
FileService configuration.
FilteredHttpRequest
An HttpRequest that filters objects as they are published.
FilteredHttpResponse
An HttpResponse that filters objects as they are published.
FilteredStreamMessage<T,​U>
A StreamMessage that filters objects as they are published.
Flags
The system properties that affect Armeria's runtime behavior.
Functions
Utility methods related with function composition.
Get
Annotation for mapping HttpMethod.GET onto specific method.
GoAwayReceivedException
A RuntimeException raised when a server sent an HTTP/2 GOAWAY frame with the lastStreamId less then the stream ID of the request.
GrantedOAuth2AccessToken
Defines a structure of the Access Token Response, as per [RFC6749], Section 5.1.
GrantedOAuth2AccessTokenBuilder
Builds an instance of GrantedOAuth2AccessToken.
GrpcClientOptions
ClientOptions to control gRPC-specific behavior.
GrpcClientStubFactory
A factory that creates a gRPC client stub.
GrpcHeaderNames
gRPC-related HTTP header names.
GrpcJsonMarshaller
A JSON marshaller for gRPC method request or response messages to and from JSON.
GrpcJsonMarshallerBuilder
A builder for creating a new GrpcJsonMarshaller that serializes and deserializes a Message to and from JSON.
GrpcMeterIdPrefixFunction
Creates a MeterIdPrefix from a RequestLog.
GrpcSerializationFormats
gRPC-related SerializationFormat instances.
GrpcService
An HttpService that implements the gRPC wire protocol.
GrpcServiceBuilder
Constructs a GrpcService to serve gRPC services from within Armeria.
GrpcStatusFunction
A mapping function that converts a Throwable into a gRPC Status.
GrpcUnsafeBufferUtil
Provides utility methods useful for storing and releasing the ByteBuf backing a Message.
GrpcWebTrailers
Retrieves gRPC-Web trailers.
HAProxyConfig
Head
Annotation for mapping HttpMethod.HEAD onto specific method.
Header
Annotation for mapping an HTTP request header onto the following elements.
HealthCheckedEndpointGroup
An EndpointGroup that filters out unhealthy Endpoints from an existing EndpointGroup, by sending periodic health check requests.
HealthCheckedEndpointGroupBuilder
A builder for creating a new HealthCheckedEndpointGroup that sends HTTP health check requests.
HealthChecker
Determines whether the Server is healthy.
HealthCheckerContext
Provides the properties and operations required for sending health check requests.
HealthCheckService
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.
HealthCheckServiceBuilder
HealthCheckServiceConfigurator
Interface used to configure a HealthCheckService on the default Armeria server.
HealthCheckUpdateHandler
Handles PUT, POST or PATCH requests sent to HealthCheckService.
HealthCheckUpdateListener
A listener interface for receiving HealthCheckService update events.
HealthCheckUpdateResult
The result of a request handled by HealthCheckUpdateHandler.
Http1HeaderNaming
Converts a normalized HTTP/2 header name to another HTTP/1 header name.
HttpClient
Sends an HttpRequest to a remote Endpoint.
HttpData
HTTP/2 data that contains a chunk of bytes.
HttpDecoder<T>
Decodes a stream of HttpObjects to N objects.
HttpDecoderInput
An input of HttpDecoder which is used to read a stream of HttpData.
HttpDecoderOutput<T>
An output of HttpDecoder which holds the decoded data.
HttpFile
A file-like HTTP resource which yields an HttpResponse.
HttpFileAttributes
The attributes of an HttpFile.
HttpFileBuilder
Builds an HttpFile from a file, a classpath resource or an HttpData.
HttpFileResponseConverterFunction
A response converter implementation which creates an HttpResponse when the result is an instance of HttpFile.
HttpHeaderNames
Contains constant definitions for the HTTP header field names.
HttpHeaders
Immutable HTTP/2 headers.
HttpHeadersBuilder
Builds an HttpHeaders.
HttpMessage
A streamed HTTP/2 message.
HttpMethod
HTTP request method.
HttpObject
The common interface for HTTP/2 message objects, HttpHeaders and HttpData.
HttpRequest
A streamed HTTP/2 Request.
HttpRequestBuilder
Builds a new HttpRequest.
HttpRequestDuplicator
A duplicator that duplicates a HttpRequest into one or more HttpRequests, which publish the same elements.
HttpRequestWriter
An HttpRequest that can have HttpObjects written to it.
HttpResponse
A streamed HTTP/2 Response.
HttpResponseDuplicator
A duplicator that duplicates a HttpResponse into one or more HttpResponses, which publish the same elements.
HttpResponseException
A RuntimeException that is raised to send an HTTP response with the content specified by a user.
HttpResponseWriter
An HttpResponse that can have HttpObjects written to it.
HttpResult<T>
An interface which helps a user specify an HttpStatus or ResponseHeaders for a response produced by an annotated HTTP service method.
HttpService
An HTTP/2 Service.
HttpServiceWithRoutes
An interface that enables getting all the Routes where an HttpService should be bound.
HttpStatus
HTTP response code and its description.
HttpStatusClass
The class of HTTP status.
HttpStatusException
A RuntimeException that is raised to send a simplistic HTTP response with minimal content by a Service.
HttpVfs
A virtual file system that provides the files requested by FileService.
InetAddressPredicates
A utility class which provides factory methods in order to easily create a Predicate of an InetAddress.
InternalExceptionMessages  
InvalidClientException
Client authentication failed (e.g., unknown client, no client authentication included, or unsupported authentication method).
InvalidGrantException
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.
InvalidRequestException
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.
InvalidResponseException
A RuntimeException raised when a client received an invalid response.
InvalidResponseException
An HTTP response that is not valid for the given request/response flow.
InvalidResponseHeadersException
An InvalidResponseException raised when a client received a response with invalid headers.
InvalidSamlRequestException
Indicates that a SAML request is not valid.
InvalidScopeException
The requested scope is invalid, unknown, malformed, or exceeds the scope granted by the resource owner.
InvocationUtil
Retrieves a Retrofit Invocation associated with a RequestLog.
JacksonRequestConverterFunction
A RequestConverterFunction which converts a JSON body of the AggregatedHttpRequest to an object using the default ObjectMapper.
JacksonResponseConverterFunction
A response converter implementation which creates an HttpResponse with content-type: application/json; charset=utf-8 or content-type: application/json-seq.
JettyService
An HttpService that dispatches its requests to a web application running in an embedded Jetty.
JettyServiceBuilder
Builds a JettyService.
JsonTextSequences
A utility class which helps to create a JavaScript Object Notation (JSON) Text Sequences from a content Publisher or Stream.
KafkaAccessLogWriter<K,​V>
An AccessLogWriter that sends access logs to a Kafka backend.
KeyStoreCredentialResolverBuilder
A builder class which creates a new KeyStoreCredentialResolver instance.
Listenable<T>
An interface that accepts item change listeners.
ListenableAsyncCloseable
A variant of AsyncCloseable which allows a user to check whether the object is closed or to get notified when closed.
ListenableHealthChecker
A HealthChecker which notifies its state change to its listeners.
LocalArmeriaPort
Specifies an active local port of an Armeria server.
LocalArmeriaPorts
Specifies active ports of an Armeria server.
LoggingClient
Decorates an HttpClient to log Requests and Responses.
LoggingClientBuilder
Builds a new LoggingClient.
LoggingDecorator
A LoggingService decorator for annotated HTTP services.
LoggingDecoratorBuilder
Builds a new logging decorator.
LoggingDecoratorFactoryFunction
A factory which creates a LoggingService decorator.
LoggingDecorators
The containing annotation type for LoggingDecorator.
LoggingRpcClient
Decorates an RpcClient to log Requests and Responses.
LoggingRpcClientBuilder
Builds a new LoggingRpcClient.
LoggingService
Decorates an HttpService to log HttpRequests and HttpResponses.
LoggingServiceBuilder
Builds a new LoggingService.
LogLevel
Log level.
LruMap<T,​U>
LRU (Least Recently Used) cache Map.
ManagementService
An HttpService that provides monitoring and management features.
MatchesHeader
Specifies a predicate which evaluates whether a request can be accepted by a service method.
MatchesHeaders
The containing annotation type for MatchesHeader.
MatchesParam
Specifies a predicate which evaluates whether a request can be accepted by a service method.
MatchesParams
The containing annotation type for MatchesParam.
MediaType
Represents an Internet Media Type (also known as a MIME Type or Content Type).
MediaTypeNames
String constants defined in MediaType class.
MediaTypeSet
An immutable Set of MediaTypes which provides useful methods for content negotiation.
MeterIdPrefix
A common prefix of Meter.Id which consists of Meter name and Tags.
MeterIdPrefixFunction
Creates a MeterIdPrefix from a RequestLog.
MeterIdPrefixFunctionCustomizer
Transforms a MeterIdPrefix into another.
MethodInfo
Metadata about a function of a Service.
MetricCollectingClient
Decorates an HttpClient to collect metrics into MeterRegistry.
MetricCollectingClientBuilder
Builds a MetricCollectingClient instance.
MetricCollectingRpcClient
Decorates an RpcClient to collect metrics into MeterRegistry.
MetricCollectingRpcClientBuilder
Builds a MetricCollectingRpcClient instance.
MetricCollectingService
Decorates an HttpService to collect metrics into MeterRegistry.
MetricCollectingServiceBuilder
Builds a MetricCollectingService instance.
MimeParsingException
MIME Parsing exception.
MockWebServerExtension
An Extension primarily for testing clients.
MoreMeters
Provides utilities for accessing MeterRegistry.
Multipart
A reactive Multipart that represents Multiple part messages.
NamedTypeInfo
Metadata about a named type.
NonNullByDefault
Indicates the return values, parameters and fields are non-nullable by default.
NonWrappingRequestContext
A skeletal RequestContext implementation that helps to implement a non-wrapping RequestContext.
NoopMeterRegistry
A MeterRegistry which does not record any values.
NoopSubscriber<T>
A Subscriber that discards all elements silently.
NullToNoContentResponseConverterFunction
A response converter implementation which creates an HttpResponse of HttpStatus.NO_CONTENT when the specified result is null.
OAuth1aToken
The bearer token of OAuth 1.0a authentication.
OAuth1aTokenBuilder
Builds a new OAuth1aToken.
OAuth2AuthorizationGrant
Represents an OAuth 2.0 Access Token Grant flow to obtain Access Token.
OAuth2Client
Decorates a HttpClient with an OAuth 2.0 Authorization Grant flow.
OAuth2ClientCredentialsGrant
An implementation of OAuth 2.0 Client Credentials Grant flow to obtain Access Token, as per [RFC6749], Section 4.4.
OAuth2ClientCredentialsGrantBuilder
OAuth2ResourceOwnerPasswordCredentialsGrant
An implementation of OAuth 2.0 Resource Owner Password Credentials Grant flow to obtain Access Token, as per [RFC6749], Section 4.3.
OAuth2ResourceOwnerPasswordCredentialsGrantBuilder
OAuth2Token
The bearer token of OAuth 2.0 authentication.
OAuth2TokenDescriptor
Defines a structure of the Token Introspection Response, as per [RFC7662], Section 2.2.
OAuth2TokenDescriptorBuilder
Builds an instance of OAuth2TokenDescriptor.
OAuth2TokenIntrospectionAuthorizer
Determines whether a given OAuth2Token is authorized for the service registered in using OAuth 2.0 Token Introspection.
OAuth2TokenIntrospectionAuthorizerBuilder
OAuth2TokenScopeValidator
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).
ObservableResponseConverterFunction
A ResponseConverterFunction which converts the Observable instance to a Flowable first, then converts it to an HttpResponse using the specified responseConverter.
ObservableResponseConverterFunction
A ResponseConverterFunction which converts the Observable instance to a Flowable first, then converts it to an HttpResponse using the specified responseConverter.
OneElementFixedStreamMessage<T>
A FixedStreamMessage that only publishes one object.
Options
Annotation for mapping HttpMethod.OPTIONS onto specific method.
Order
Specifies an order which is used to sort the annotated service methods.
OsType
Operating system.
Param
Annotation for mapping a parameter of a request onto the following elements.
Patch
Annotation for mapping HttpMethod.PATCH onto specific method.
Path
Annotation for mapping dynamic web requests onto specific method.
PathPrefix
Annotation that can be used on a class as a path prefix for all the methods that handle http request.
Paths
The containing annotation type for Path.
PooledObjects
Utility class that provides ways to create a pooled HttpData and manage its life cycle.
Post
Annotation for mapping HttpMethod.POST onto specific method.
Produces
Specifies a media type which would be produced by the service method or class.
ProducesBinary
An alias for @Produces(MediaTypeNames.APPLICATION_BINARY).
ProducesEventStream
An alias for @Produces(MediaTypeNames.EVENT_STREAM) and @ResponseConverter(ServerSentEventResponseConverterFunction.class).
ProducesGroup
The containing annotation type for Produces.
ProducesJson
An alias for @Produces(MediaTypeNames.JSON_UTF_8).
ProducesJsonSequences
An alias for @Produces(MediaTypeNames.JSON_SEQ).
ProducesOctetStream
An alias for @Produces(MediaTypeNames.OCTET_STREAM).
ProducesProtobuf
An alias for @Produces(MediaTypeNames.PROTOBUF).
ProducesText
An alias for @Produces(MediaTypeNames.PLAIN_TEXT_UTF_8).
PrometheusExpositionService
Exposes Prometheus metrics in text format 0.0.4.
PrometheusExpositionServiceBuilder
PrometheusMeterRegistries
Provides the convenient factory methods for PrometheusMeterRegistry with more sensible defaults for NamingConvention.
PropertiesEndpointGroup
PropertiesEndpointGroupBuilder
ProtobufRequestConverterFunction
A RequestConverterFunction which converts a Protocol Buffers or JSON body of the AggregatedHttpRequest to an object.
ProtobufRequestConverterFunctionProvider
Provides a ProtobufRequestConverterFunction to annotated services.
ProtobufResponseConverterFunction
A ResponseConverterFunction which creates an HttpResponse with content-type: application/protobuf or content-type: application/json; charset=utf-8.
ProtobufResponseConverterFunctionProvider
Provides a ProtobufResponseConverterFunction to annotated services.
ProtocolViolationException
A RuntimeException raised when a remote peer violated the current SessionProtocol.
ProxiedAddresses
An interface to provide source and destination addresses delivered from a proxy server.
ProxyConfig
Base configuration for proxy settings used by ClientFactory.
ProxyConfigSelector
Selects the ProxyConfig to use when connecting to a network resource specified by the SessionProtocol and Endpoint parameter.
ProxyType
The proxy protocol type.
PublisherBasedStreamMessage<T>
Adapts a Publisher into a StreamMessage.
Put
Annotation for mapping HttpMethod.PUT onto specific method.
QueryParams
Immutable HTTP query parameters.
QueryParamsBuilder
Builds a QueryParams.
RateLimitingDecorator
A ThrottlingService decorator for annotated HTTP services.
RateLimitingDecoratorFactoryFunction
A factory which creates a ThrottlingService decorator with a ThrottlingStrategy.rateLimiting(double, String).
RateLimitingDecorators
The containing annotation type for RateLimitingDecorator.
RecordedRequest
A request that has been made to a MockWebServerExtension.
RedirectService
An HttpService that sends a redirect response such as "307 Temporary Redirect".
RefusedStreamException
A RuntimeException raised when a server set HTTP/2 MAX_CONCURRENT_STREAMS to 0, which means a client can't send anything.
RegexBasedSanitizer
Regex based sanitizer.
RegularFixedStreamMessage<T>
A FixedStreamMessage that publishes an arbitrary number of objects.
RejectedRouteHandler
A handler that is invoked when a ServerBuilder rejects to bind an HttpService at a certain Route.
ReleasableHolder<T>
A holder of releasable resource ReleasableHolder.
Request
A request.
RequestCancellationException
A CancellationException raised when a request is cancelled by the user.
RequestContext
Provides information about a Request, its Response and related utilities.
RequestContextAssembly
Utility class to keep RequestContext during RxJava operations.
RequestContextAssembly
Utility class to keep RequestContext during RxJava operations.
RequestContextCurrentTraceContext
RequestContextCurrentTraceContextBuilder
A builder of RequestContextCurrentTraceContext to enable tracing of an Armeria-based application.
RequestContextExporter
Exports the specified properties from current RequestContext to Map.
RequestContextExporterBuilder
RequestContextExportingAppender
A Logback Appender that exports the properties of the current RequestContext to MDC.
RequestContextHooks
Utility class to keep RequestContext during Reactor operations.
RequestContextStorage
The storage for storing RequestContext.
RequestContextStorageProvider
Creates a new RequestContextStorage dynamically via Java SPI (Service Provider Interface).
RequestContextStorageWrapper
Wraps an existing RequestContextStorage.
RequestContextWrapper<T extends RequestContext>
Wraps an existing RequestContext.
RequestConverter
Specifies a RequestConverterFunction class which converts an AggregatedHttpRequest to an object.
RequestConverterFunction
Converts an AggregatedHttpRequest to an object.
RequestConverterFunctionProvider
A RequestConverterFunction provider interface which creates a new RequestConverterFunction for converting an AggregatedHttpRequest to an object of the given type.
RequestConverters
The containing annotation type for RequestConverter.
RequestHeaders
Immutable HTTP/2 headers for an HttpRequest.
RequestHeadersBuilder
Builds a RequestHeaders.
RequestId
An identifier of a Request-Response pair.
RequestLog
A set of informational properties collected while processing a Request and Response.
RequestLogAccess
Provides the access to a RequestLog or RequestOnlyLog, while ensuring the interested RequestLogPropertys are available.
RequestLogAvailabilityException
A RuntimeException raised when accessing a RequestLog property that's not available yet.
RequestLogBuilder
Updates a RequestLog with newly available information.
RequestLogProperty
A property of RequestLog, used for identifying properties that have been populated during request processing.
RequestObject
Specifies which element should be converted by RequestConverterFunction.
RequestOnlyLog
A set of informational properties for request-side only, collected while consuming a Request.
RequestScopedMdc
Provides the access to request-scoped MDC properties.
RequestTimeoutException
A TimeoutException raised when a request has not been received from a client within timeout.
Response
A response stream or a holder of the future result value.
ResponseCancellationException
A CancellationException raised when a response is cancelled by the user.
ResponseConverter
Specifies a ResponseConverterFunction class which converts the result to HttpResponse.
ResponseConverterFunction
Converts a result object to HttpResponse.
ResponseConverterFunctionProvider
A ResponseConverterFunction provider interface which creates a new ResponseConverterFunction for converting an object of the given type and functions.
ResponseConverters
The containing annotation type for ResponseConverter.
ResponseHeaders
Immutable HTTP/2 headers for an HttpResponse.
ResponseHeadersBuilder
Builds a ResponseHeaders.
ResponseTimeoutException
A TimeoutException raised when a response has not been received from a server within timeout.
ResteasyService<T>
RESTEasy service implementing Armeria's HttpService.
ResteasyServiceBuilder<T>
RetrofitMeterIdPrefixFunction
Returns the default function for retrofit that creates a MeterIdPrefix with the specified name and the Tags derived from the RequestLog properties and Invocation.
RetryConfig<T extends Response>
Holds retry config used by a RetryingClient.
RetryConfigBuilder<T extends Response>
Builds a RetryConfig.
RetryConfigMapping<T extends Response>
Returns a RetryConfig given the ClientRequestContext.
RetryDecision
A RetryDecision that determines whether a RetryRule retries with a Backoff, skips the current RetryRule or no retries.
RetryingClient
An HttpClient decorator that handles failures of an invocation and retries HTTP requests.
RetryingClientBuilder
Builds a new RetryingClient or its decorator function.
RetryingRpcClient
An RpcClient decorator that handles failures of an invocation and retries RPC requests.
RetryingRpcClientBuilder
Builds a new RetryingRpcClient or its decorator function.
RetryRule
Determines whether a failed request should be retried.
RetryRuleBuilder
A builder for creating a new RetryRule.
RetryRuleWithContent<T extends Response>
Determines whether a failed request should be retried using the content of a Response.
RetryRuleWithContentBuilder<T extends Response>
A builder for creating a new RetryRuleWithContent.
Route
Route maps from an incoming HTTP request to an HttpService based on its path, method, content type and accepted types.
RouteBuilder
Builds a new Route.
Routed<T>
A value mapped by Router.
RoutePathType
The type of the path which was specified when a Route is created.
Router<V>
Finds a mapping that matches a given RoutingContext.
Routers
A factory that creates a Router instance.
RoutingContext
Holds the parameters which are required to find a service available to handle the request.
RoutingResult
The result returned by Route.apply(RoutingContext, boolean).
RoutingResultBuilder
Builds a new RoutingResult.
RoutingResultType
The type of RoutingResult.
RpcClient
Sends an RpcRequest to a remote Endpoint.
RpcRequest
An RPC Request.
RpcResponse
An RPC Response.
RpcService
An RPC Service.
RpcServiceWithRoutes
An interface that enables getting all the Routes where an RpcService should be bound.
SafeCloseable
An AutoCloseable whose SafeCloseable.close() method does not throw an exception.
SamlAssertionConsumerConfig
A configuration for an assertion consumer service of a service provider.
SamlAssertionConsumerConfigBuilder
A builder which builds a SamlAssertionConsumerConfig.
SamlBindingProtocol
SAML binding protocols.
SamlEndpoint
A SAML service URL and its binding protocol.
SamlException
Indicates that an error occurred while processing a SAML request.
SamlIdentityProviderConfig
A configuration for an identity provider.
SamlIdentityProviderConfigBuilder
A builder which builds a SamlIdentityProviderConfig.
SamlIdentityProviderConfigSelector
A SamlIdentityProviderConfig selector for the request.
SamlNameIdFormat
SAML name ID formats.
SamlNameIdPolicy
SAML name ID format and its option.
SamlRequestIdManager
An interface which generates and validates a request ID when transferring a SAML message between a service provider and an identity provider.
SamlServiceProvider
A SAML service provider implementation.
SamlServiceProviderBuilder
A builder which builds a SamlServiceProvider.
SamlSingleLogoutHandler
A callback which is invoked when a SAML single logout request is received.
SamlSingleSignOnHandler
Callbacks which are invoked to handle SAML messages exchanging with an identity provider.
SamlUtil
A utility class which helps a user to easily handle a SAML message.
Sampler<T>
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.
Scheme
SelfSignedCertificateExtension
An Extension that provides a temporary self-signed certificate.
SelfSignedCertificateRule
A TestRule that provides a temporary self-signed certificate.
SerializationFormat
Serialization format of a remote procedure call and its reply.
SerializationFormatProvider
Registers the SerializationFormats dynamically via Java SPI (Service Provider Interface).
SerializationFormatProvider.Entry
A registration entry of a SerializationFormat.
Server
Listens to ServerPorts and delegates client requests to Services.
ServerBuilder
Builds a new Server and its ServerConfig.
ServerCacheControl
Directives for HTTP caching mechanisms in responses.
ServerCacheControlBuilder
Creates a new ServerCacheControl using the builder pattern.
ServerConfig
Server configuration.
ServerExtension
An Extension that allows easy set-up and tear-down of a Server.
ServerListener
Listens to life cycle events of a Server.
ServerListenerAdapter
A skeletal ServerListener implementation in order for a user to implement only the methods what he or she really needs.
ServerListenerBuilder
Builds a new ServerListener.
ServerPort
A pair of server-side bind address and SessionProtocol.
ServerRule
A TestRule that allows easy set-up and tear-down of a Server.
ServerSentEvent
An interface for the Server-Sent Events specification.
ServerSentEventBuilder
A builder which creates a ServerSentEvent instance.
ServerSentEventResponseConverterFunction
A response converter implementation which creates an HttpResponse with content-type: text/event-stream.
ServerSentEvents
A utility class which helps to create a Server-Sent Events stream from a content Publisher or Stream.
ServerSetsInstance
A class that represents a service instance used by Finagle ServerSets.
ServerSetsRegistrationSpecBuilder
Service<I extends Request,​O extends Response>
Handles a Request received by a Server.
ServiceBindingBuilder
A builder class for binding an HttpService fluently.
ServiceCallbackInvoker
A helper class that invokes the callback methods in Service.
ServiceConfig
An HttpService configuration.
ServiceInfo
Metadata about a Service.
ServiceName
Annotation for service name that is often used as a meter tag or distributed trace's span name.
ServiceNaming
Generates the default name of a Service from its ServiceRequestContext.
ServiceRequestContext
Provides information about an invocation and related utilities.
ServiceRequestContextBuilder
Builds a new ServiceRequestContext.
ServiceRequestContextWrapper
Wraps an existing ServiceRequestContext.
ServiceSpecification
The specification of one or more Services that provides their ServiceInfos and NamedTypeInfos.
ServiceWithRoutes<I extends Request,​O extends Response>
An interface that enables getting all the Routes where a Service should be bound.
SessionProtocol
Session-level protocol that provides facilities such as framing and flow control.
SessionProtocolNegotiationCache
Keeps the recent SessionProtocol negotiation failures.
SessionProtocolNegotiationException
An exception triggered when failed to negotiate the desired SessionProtocol with a server.
SettableHealthChecker
A simple ListenableHealthChecker whose state can be set by a caller.
SignalLengthGetter<T>
A function that accepts one signal and produces the length of the signal.
SimpleDecoratingClient<I extends Request,​O extends Response>
Decorates a Client.
SimpleDecoratingHttpClient
Decorates an HttpClient.
SimpleDecoratingHttpService
An HttpService that decorates another HttpService.
SimpleDecoratingRpcClient
Decorates an RpcClient.
SimpleDecoratingRpcService
An RpcService that decorates another RpcService.
SimpleDecoratingService<I extends Request,​O extends Response>
A Service that decorates another Service.
Socks4ProxyConfig
SOCKS4 proxy configuration.
Socks5ProxyConfig
SOCKS5 proxy configuration.
SplitHttpResponse
An HttpResponse which splits a stream of HttpObjects into HTTP headers and payloads.
Ssl
Simple server-independent abstraction for SSL configuration.
StackTraceElementProto
An element in a stack trace, based on the Java type of the same name.
StackTraceElementProto.Builder
An element in a stack trace, based on the Java type of the same name.
StackTraceElementProtoOrBuilder  
StartStopSupport<T,​U,​V,​L>
Provides asynchronous start-stop life cycle support.
StatusCauseException
A RuntimeException reconstructed from debug information in a failed gRPC response, containing information about the cause of the exception at the server side.
StatusCode
An annotation which specifies a default HTTP status code of a response produced by an annotated HTTP service.
StatusMessageEscaper
Utility to escape status messages (e.g., error messages) for saving to ascii headers.
StreamDecoder Deprecated.
Use StreamDecoder instead.
StreamDecoder
An interface for objects that apply HTTP content decoding to incoming HttpData.
StreamDecoderFactory Deprecated.
StreamDecoderFactory
An interface that constructs a new StreamDecoder for a given Content-Encoding header value.
StreamingHttpFile<T extends Closeable>
A skeletal HttpFile that simplifies the streaming of potentially large content.
StreamMessage<T>
A variant of Reactive Streams Publisher, which allows only one Subscriber.
StreamMessageDuplicator<T>
A duplicator that duplicates a StreamMessage into one or more StreamMessages, which publish the same elements.
StreamMessageWrapper<T>
Wraps a StreamMessage and forwards its method invocations to delegate.
StreamWriter<T>
Produces the objects to be published by a StreamMessage.
StringRequestConverterFunction
A RequestConverterFunction which converts a text body of the AggregatedHttpRequest to a String.
StringResponseConverterFunction
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.
StructInfo
Metadata about a struct type.
SubscriptionOption
Options used when subscribing to a StreamMessage.
SystemInfo
Provides utilities for accessing the information about the current system and process.
TextFormatter
A utility class to format things as a String with ease.
ThreadFactories
Provides a builder for ThreadFactory.
ThreadFactoryBuilder
Builds a new ThreadFactory.
ThriftCall
A container of a Thrift one-way or two-way call object (TBase) and its header (TMessage).
ThriftCallService
An RpcService that handles a Thrift RpcRequest.
ThriftFuture<T>
A CompletableFuture that can be passed in as an AsyncMethodCallback when making an asynchronous client-side Thrift RPC.
ThriftJacksonModule
Jackson Module for Thrift types.
ThriftListenableFuture<T>
A ListenableFuture that can be passed in as an AsyncMethodCallback when making an asynchronous client-side Thrift RPC.
ThriftMessage
A container of a Thrift message produced by Apache Thrift.
ThriftProtocolFactories
Provides a set of well-known TProtocolFactorys.
ThriftProtocolFactoryProvider
SPI Provider for links from SerializationFormat to TProtocolFactory.
ThriftProtocolFactoryProvider.Entry
ThriftReply
A container of a Thrift reply or exception object (TBase or TApplicationException) and its header (TMessage).
ThriftSerializationFormats
Provides Thrift-related SerializationFormat instances and their TProtocolFactorys.
ThriftServiceEntry
The information about a Thrift service served by THttpService or ThriftCallService.
ThrottlingAcceptHandler<I extends Request,​O extends Response>
A callback which is invoked to handle accepted (successful) requests indicated by ThrottlingStrategy.
ThrottlingHeaders
A RateLimit Header Scheme for HTTP.
ThrottlingRejectHandler<I extends Request,​O extends Response>
A callback which is invoked to handle rejected (failure) requests indicated by ThrottlingStrategy.
ThrottlingRpcService
Decorates an RPC Service to throttle incoming requests.
ThrottlingRpcServiceBuilder
Builds a new ThrottlingRpcService.
ThrottlingService
Decorates an HttpService to throttle incoming requests.
ThrottlingServiceBuilder
Builds a new ThrottlingService.
ThrottlingStrategy<T extends Request>
Determines whether a request should be throttled.
ThrowableProto
An exception that was thrown by some code, based on the Java type of the same name.
ThrowableProto.Builder
An exception that was thrown by some code, based on the Java type of the same name.
ThrowableProtoOrBuilder  
THttpClient
A generic Thrift-over-HTTP client.
THttpService
An HttpService that handles a Thrift call.
THttpServiceBuilder
A fluent builder to build an instance of THttpService.
Ticker
A time source; returns a time value representing the number of nanoseconds elapsed since some fixed but arbitrary point in time.
TimeoutException
A RuntimeException raised when a requested invocation does not complete before its deadline.
TimeoutMode
The timeout mode.
TokenBucket
Stores configuration of the Token-Bucket algorithm, comprised of multiple limits.
TokenBucketBuilder
Builds a TokenBucket instance.
TokenBucketThrottlingStrategy<T extends Request>
A ThrottlingStrategy that provides a throttling strategy based on Token-Bucket algorithm.
TokenBucketThrottlingStrategyBuilder<T extends Request>
TokenRequestException
A common token request exception type.
TokenRevocation
Implements Token Revocation request/response flow, as per [RFC7009].
TokenRevocationBuilder
TomcatService
An HttpService that dispatches its requests to a web application running in an embedded Tomcat.
TomcatServiceBuilder
Builds a TomcatService.
TomcatServiceException
A RuntimeException that is raised when configuring or starting an embedded Tomcat fails.
Trace
Annotation for mapping HttpMethod.TRACE onto specific method.
TransientHttpService
An HttpService that handles transient requests, for example, health check requests.
TransientRpcService
An RpcService that handles transient requests, for example, health check requests.
TransientService<I extends Request,​O extends Response>
A Service that handles transient requests, for example, health check requests.
TransientServiceBuilder
TransientServiceOption
Specifies which features should be enabled for a TransientService.
TransportType
Native transport types.
TTextProtocolFactory
The TProtocolFactory that creates a TTextProtocol.
TwoElementFixedStreamMessage<T>
A FixedStreamMessage that publishes two objects.
TypeSignature
Type signature of a method parameter, a method return value or a struct/exception field.
UnaryGrpcClient
A UnaryGrpcClient can be used to make requests to a gRPC server without depending on gRPC stubs.
UnauthorizedClientException
The authenticated client is not authorized to use this authorization grant type.
UnmodifiableFuture<T>
A CompletableFuture which prevents the caller from completing it.
UnprocessedRequestException
A RuntimeException raised when it is certain that a request has not been handled by a server and thus can be retried safely.
UnstableApi
Indicates the API of the target is not mature enough to guarantee the compatibility between releases.
UnsupportedGrantTypeException
The authorization grant type is not supported by the authorization server.
UnsupportedMediaTypeException
A response Content-Type header does not match the expected type.
UnsupportedResponseException
A response type in not supported by the given request/response flow.
UnsupportedTokenTypeException
The authorization server does not support the revocation of the presented token type.
Unwrappable
Provides a way to unwrap an object in decorator pattern, similar to down-casting in an inheritance pattern.
UserClient<I extends Request,​O extends Response>
A base class for implementing a user's entry point for sending a Request.
Version
Retrieves the version information of available Armeria artifacts.
VirtualHost
VirtualHostAnnotatedServiceBindingBuilder
A builder class for binding an HttpService to a virtual host fluently.
VirtualHostBuilder
Builds a new VirtualHost.
VirtualHostDecoratingServiceBindingBuilder
A builder class for binding a decorator to a Route fluently.
VirtualHostServiceBindingBuilder
A builder class for binding an HttpService fluently.
WebClient
An asynchronous web client.
WebClientBuilder
Creates a new web client that connects to the specified URI using the builder pattern.
WebClientRequestPreparation
Prepares and executes a new HttpRequest for WebClient.
WeightRampingUpStrategyBuilder
Builds a weight ramping up EndpointSelectionStrategy which ramps the weight of newly added Endpoints.
WriteTimeoutException
A TimeoutException raised when a client failed to send a request to the wire within timeout.
ZooKeeperDiscoverySpec
A discovery specification for ZooKeeperEndpointGroup.
ZooKeeperEndpointGroup
A ZooKeeper-based EndpointGroup implementation.
ZooKeeperEndpointGroupBuilder
ZooKeeperRegistrationSpec
A registration specification for ZooKeeperUpdatingListener.
ZooKeeperUpdatingListener
A ServerListener which registers the current Server to ZooKeeper as an ephemeral node.
ZooKeeperUpdatingListenerBuilder
Builds a new ZooKeeperUpdatingListener, which registers the server to a ZooKeeper cluster.