- name() - Method in class io.servicetalk.http.api.DefaultHttpCookiePair
-
- name() - Method in class io.servicetalk.http.api.DefaultHttpSetCookie
-
- name() - Method in interface io.servicetalk.http.api.HttpCookiePair
-
- name() - Method in class io.servicetalk.http.api.HttpProtocolVersion
-
- name() - Method in class io.servicetalk.http.api.HttpRequestMethod
-
- name() - Method in interface io.servicetalk.transport.api.ConnectionContext.Protocol
-
Returns name of the protocol.
- names() - Method in class io.servicetalk.http.api.EmptyHttpHeaders
-
- names() - Method in interface io.servicetalk.http.api.HttpHeaders
-
Returns a Set
of all header names in this object.
- nameServerAddressStream(String) - Method in interface io.servicetalk.dns.discovery.netty.DnsServerAddressStreamProvider
-
Ask this provider for the name servers to query for hostname
.
- nameServerAddressStream(String) - Method in class io.servicetalk.dns.discovery.netty.SingletonDnsServerAddressStreamProvider
-
- nAvailable() - Method in interface io.servicetalk.dns.discovery.netty.DnsServiceDiscovererObserver.ResolutionResult
-
- ndots(int) - Method in class io.servicetalk.dns.discovery.netty.DefaultDnsServiceDiscovererBuilder
-
Set the number of dots which must appear in a name before an initial absolute query is made.
- nettyChannel() - Method in class io.servicetalk.transport.netty.internal.DefaultNettyConnection
-
- nettyChannel() - Method in interface io.servicetalk.transport.netty.internal.NettyConnectionContext
-
Return the Netty Channel
backing this connection.
- NettyChannelListenableAsyncCloseable - Class in io.servicetalk.transport.netty.internal
-
- NettyChannelListenableAsyncCloseable(Channel, Executor) - Constructor for class io.servicetalk.transport.netty.internal.NettyChannelListenableAsyncCloseable
-
New instance.
- NettyConnection<Read,Write> - Interface in io.servicetalk.transport.netty.internal
-
A wrapper over a physical connection providing a way to read/write as a
Publisher
.
- NettyConnectionContext - Interface in io.servicetalk.transport.netty.internal
-
- NettyConnectionContext.FlushStrategyProvider - Interface in io.servicetalk.transport.netty.internal
-
- NettyFutureCompletable - Class in io.servicetalk.transport.netty.internal
-
- NettyFutureCompletable(Supplier<Future<?>>) - Constructor for class io.servicetalk.transport.netty.internal.NettyFutureCompletable
-
New instance.
- NettyIoExecutor - Interface in io.servicetalk.transport.netty.internal
-
- NettyIoExecutors - Class in io.servicetalk.transport.netty.internal
-
- NettyIoExecutors - Class in io.servicetalk.transport.netty
-
Factory methods to create
IoExecutor
s using netty as the transport.
- NettyPipelineSslUtils - Class in io.servicetalk.transport.netty.internal
-
Utilities for ChannelPipeline
and SSL/TLS.
- NettyServerContext - Class in io.servicetalk.transport.netty.internal
-
- NETWORK_AUTHENTICATION_REQUIRED - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
511 Network Authentication Required
- networkAuthenticationRequired() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- networkAuthenticationRequired() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- networkAuthenticationRequired() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- never() - Static method in class io.servicetalk.concurrent.api.Completable
-
- never() - Static method in class io.servicetalk.concurrent.api.Publisher
-
- never() - Static method in class io.servicetalk.concurrent.api.Single
-
Creates a
Single
that never terminates.
- newAsciiString(String) - Static method in class io.servicetalk.http.api.CharSequences
-
Create a new CharSequence
from the specified input
, supporting only 8-bit ASCII characters, and
with a case-insensitive hashCode
.
- newAsciiString(Buffer) - Static method in class io.servicetalk.http.api.CharSequences
-
Create a new CharSequence
from the specified input
, supporting only 8-bit ASCII characters, and
with a case-insensitive hashCode
.
- newBlockingCall(GrpcSerializationProvider, Class<Req>, Class<Resp>) - Method in interface io.servicetalk.grpc.api.GrpcClientCallFactory
-
- newBlockingClient(GrpcClientCallFactory) - Method in class io.servicetalk.grpc.api.GrpcClientFactory
-
- newBlockingIterableProcessor() - Static method in class io.servicetalk.concurrent.api.Processors
-
Create a new BlockingIterable.Processor
.
- newBlockingIterableProcessor(int) - Static method in class io.servicetalk.concurrent.api.Processors
-
Create a new BlockingIterable.Processor
.
- newBlockingIterableProcessor(BlockingProcessorSignalsHolder<T>) - Static method in class io.servicetalk.concurrent.api.Processors
-
Create a new BlockingIterable.Processor
.
- newBlockingRequestStreamingCall(GrpcSerializationProvider, Class<Req>, Class<Resp>) - Method in interface io.servicetalk.grpc.api.GrpcClientCallFactory
-
- newBlockingResponseStreamingCall(GrpcSerializationProvider, Class<Req>, Class<Resp>) - Method in interface io.servicetalk.grpc.api.GrpcClientCallFactory
-
- newBlockingStreamingCall(GrpcSerializationProvider, Class<Req>, Class<Resp>) - Method in interface io.servicetalk.grpc.api.GrpcClientCallFactory
-
- newBuffer() - Method in interface io.servicetalk.buffer.api.BufferAllocator
-
Create a new buffer.
- newBuffer(boolean) - Method in interface io.servicetalk.buffer.api.BufferAllocator
-
Create a new buffer.
- newBuffer(int) - Method in interface io.servicetalk.buffer.api.BufferAllocator
-
Create a new buffer with the given initial capacity.
- newBuffer(int, boolean) - Method in interface io.servicetalk.buffer.api.BufferAllocator
-
Create a new buffer with the given initial capacity.
- newBufferFrom(ByteBuf) - Static method in class io.servicetalk.buffer.netty.BufferUtils
-
Return a
Buffer
for the given
ByteBuf
.
- newCachedThreadExecutor() - Static method in class io.servicetalk.concurrent.api.Executors
-
Creates a new
Executor
that creates as many threads as required but reuses threads when possible.
- newCachedThreadExecutor(ThreadFactory) - Static method in class io.servicetalk.concurrent.api.Executors
-
Creates a new
Executor
that creates as many threads as required but reuses threads when possible.
- newCall(GrpcSerializationProvider, Class<Req>, Class<Resp>) - Method in interface io.servicetalk.grpc.api.GrpcClientCallFactory
-
- newClient(GrpcClientCallFactory) - Method in class io.servicetalk.grpc.api.GrpcClientFactory
-
- newClient(FilterableClient) - Method in class io.servicetalk.grpc.api.GrpcClientFactory
-
Create a new Client
using the passed FilterableClient
.
- newCompletableProcessor() - Static method in class io.servicetalk.concurrent.api.Processors
-
Create a new CompletableSource.Processor
that allows for multiple
subscribes
.
- newCompositeBuffer() - Method in interface io.servicetalk.buffer.api.BufferAllocator
-
Create a new composite buffer.
- newCompositeBuffer(int) - Method in interface io.servicetalk.buffer.api.BufferAllocator
-
Create a new composite buffer.
- newCompositeCloseable() - Static method in class io.servicetalk.concurrent.api.AsyncCloseables
-
- newConnection(ResolvedAddress) - Method in interface io.servicetalk.client.api.ConnectionFactory
-
Creates and asynchronously returns a connection.
- newConnection(ResolvedAddress) - Method in class io.servicetalk.client.api.DelegatingConnectionFactory
-
- newConnection() - Method in interface io.servicetalk.client.api.LoadBalancedAddress
-
Creates and asynchronously returns a connection for this address.
- newConnectionRefusedException(ResolvedAddress) - Method in interface io.servicetalk.client.api.LimitingConnectionFactoryFilter.ConnectionLimiter
-
- newController(Publisher<? extends ConsumableEvent<Integer>>, Completable, int) - Static method in class io.servicetalk.client.api.internal.RequestConcurrencyControllers
-
- newController(Publisher<? extends ConsumableEvent<Integer>>, Completable, int) - Static method in class io.servicetalk.client.api.internal.ReservableRequestConcurrencyControllers
-
- newDefaultEstimator() - Static method in class io.servicetalk.transport.netty.internal.WriteDemandEstimators
-
- newDirectBuffer(long, long, int) - Static method in class io.servicetalk.utils.internal.PlatformDependent
-
Creates a new ByteBuffer
for the specified pre-allocated direct memory.
- newEmptyTrailers() - Method in class io.servicetalk.http.api.DefaultHttpHeadersFactory
-
- newEmptyTrailers() - Method in interface io.servicetalk.http.api.HttpHeadersFactory
-
- newEmptyTrailers() - Method in class io.servicetalk.http.netty.H2HeadersFactory
-
- newExceptionForInvalidRequestN(long) - Static method in class io.servicetalk.concurrent.internal.SubscriberUtils
-
- newFilter(Client, FilterFactory) - Method in class io.servicetalk.grpc.api.GrpcClientFactory
-
Create a new Filter
using the passed Client
and FilterFactory
.
- newFixedSizeExecutor(int) - Static method in class io.servicetalk.concurrent.api.Executors
-
Creates a new
Executor
that has a fixed number of threads as specified by the
size
.
- newFixedSizeExecutor(int, ThreadFactory) - Static method in class io.servicetalk.concurrent.api.Executors
-
Creates a new
Executor
that has a fixed number of threads as specified by the
size
.
- newGrpcClientCallFactory() - Method in class io.servicetalk.grpc.api.GrpcClientBuilder
-
- newHeaders() - Method in class io.servicetalk.http.api.DefaultHttpHeadersFactory
-
- newHeaders() - Method in interface io.servicetalk.http.api.HttpHeadersFactory
-
- newHeaders() - Method in class io.servicetalk.http.netty.H2HeadersFactory
-
- newInstance(Class<?>, String) - Static method in exception io.servicetalk.transport.netty.internal.StacklessClosedChannelException
-
- newKey(String) - Static method in class io.servicetalk.client.api.partition.PartitionAttributes.Key
-
- newKey() - Static method in class io.servicetalk.client.api.partition.PartitionAttributes.Key
-
Create a new instance.
- newKey(String) - Static method in class io.servicetalk.concurrent.api.AsyncContextMap.Key
-
- newKey() - Static method in class io.servicetalk.concurrent.api.AsyncContextMap.Key
-
Create a new instance.
- newLargePayload() - Static method in class io.servicetalk.http.router.jersey.TestUtils
-
- newLoadBalancer(Publisher<? extends ServiceDiscovererEvent<ResolvedAddress>>, ConnectionFactory<ResolvedAddress, ? extends C>) - Method in interface io.servicetalk.client.api.LoadBalancerFactory
-
- newLoadBalancer(Publisher<? extends ServiceDiscovererEvent<ResolvedAddress>>, ConnectionFactory<ResolvedAddress, ? extends FilterableStreamingHttpLoadBalancedConnection>) - Method in interface io.servicetalk.http.api.HttpLoadBalancerFactory
-
- newLoadBalancer(Publisher<? extends ServiceDiscovererEvent<ResolvedAddress>>, ConnectionFactory<ResolvedAddress, ? extends FilterableStreamingHttpLoadBalancedConnection>) - Method in class io.servicetalk.http.netty.DefaultHttpLoadBalancerFactory
-
- newLoadBalancer(Publisher<? extends ServiceDiscovererEvent<ResolvedAddress>>, ConnectionFactory<ResolvedAddress, ? extends C>) - Method in class io.servicetalk.loadbalancer.RoundRobinLoadBalancer.RoundRobinLoadBalancerFactory
-
- newMpscQueue(int) - Static method in class io.servicetalk.utils.internal.PlatformDependent
-
Create a new Queue
which is safe to use for multiple producers (different threads) and a single
consumer (one thread!).
- newMpscQueue(int, int) - Static method in class io.servicetalk.utils.internal.PlatformDependent
-
Create a new Queue
which is safe to use for multiple producers (different threads) and a single
consumer (one thread!).
- newOffloaderFor(Executor) - Static method in class io.servicetalk.concurrent.internal.SignalOffloaders
-
- newPartitionMap(Function<PartitionAttributes, T>) - Method in class io.servicetalk.client.api.internal.partition.PowerSetPartitionMapFactory
-
- newPartitionMap(Function<PartitionAttributes, T>) - Method in interface io.servicetalk.client.api.partition.PartitionMapFactory
-
- newPublisherProcessor() - Static method in class io.servicetalk.concurrent.api.Processors
-
Create a new PublisherSource.Processor
that allows for a single
subscribe
.
- newPublisherProcessor(int) - Static method in class io.servicetalk.concurrent.api.Processors
-
Create a new PublisherSource.Processor
that allows for a single
subscribe
.
- newPublisherProcessor(PublisherProcessorSignalsHolder<T>) - Static method in class io.servicetalk.concurrent.api.Processors
-
Create a new PublisherSource.Processor
that allows for a single
subscribe
.
- newPublisherProcessorDropHeadOnOverflow(int) - Static method in class io.servicetalk.concurrent.api.Processors
-
Create a new PublisherSource.Processor
that allows for a single
subscribe
.
- newPublisherProcessorDropTailOnOverflow(int) - Static method in class io.servicetalk.concurrent.api.Processors
-
Create a new PublisherSource.Processor
that allows for a single
subscribe
.
- newRequest(HttpRequestMethod, String) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequestFactory
-
- newRequest(HttpRequestMethod, String) - Method in class io.servicetalk.http.api.DefaultStreamingHttpRequestResponseFactory
-
- newRequest(HttpRequestMethod, String) - Method in interface io.servicetalk.http.api.HttpRequestFactory
-
- newRequest(HttpRequestMethod, String) - Method in class io.servicetalk.http.api.ReservedStreamingHttpConnectionFilter
-
- newRequest(HttpRequestMethod, String) - Method in class io.servicetalk.http.api.StreamingHttpClientFilter
-
- newRequest(HttpRequestMethod, String) - Method in class io.servicetalk.http.api.StreamingHttpConnectionFilter
-
- newRequest(HttpRequestMethod, String) - Method in interface io.servicetalk.http.api.StreamingHttpRequestFactory
-
- newRequest(HttpRequestMethod, String, HttpProtocolVersion, HttpHeaders, BufferAllocator, HttpHeadersFactory) - Static method in class io.servicetalk.http.api.StreamingHttpRequests
-
- newRequestMetaData(HttpProtocolVersion, HttpRequestMethod, String, HttpHeaders) - Static method in class io.servicetalk.http.api.HttpRequestMetaDataFactory
-
Create a new instance.
- newRequestMethodProperties(boolean, boolean, boolean) - Static method in class io.servicetalk.http.api.HttpRequestMethod.Properties
-
- newRequestStreamingCall(GrpcSerializationProvider, Class<Req>, Class<Resp>) - Method in interface io.servicetalk.grpc.api.GrpcClientCallFactory
-
- newResponse(HttpResponseStatus) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- newResponse(HttpResponseStatus) - Method in class io.servicetalk.http.api.DefaultStreamingHttpRequestResponseFactory
-
- newResponse(HttpResponseStatus) - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- newResponse(HttpResponseStatus) - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- newResponse(HttpResponseStatus, HttpProtocolVersion, HttpHeaders, BufferAllocator, HttpHeadersFactory) - Static method in class io.servicetalk.http.api.StreamingHttpResponses
-
Create a new instance using HTTP 1.1 with empty payload body.
- newResponseMetaData(HttpProtocolVersion, HttpResponseStatus, HttpHeaders) - Static method in class io.servicetalk.http.api.HttpResponseMetaDataFactory
-
Create a new instance.
- newResponseStreamingCall(GrpcSerializationProvider, Class<Req>, Class<Resp>) - Method in interface io.servicetalk.grpc.api.GrpcClientCallFactory
-
- newRoundRobinFactory() - Static method in class io.servicetalk.loadbalancer.RoundRobinLoadBalancer
-
- newRule() - Static method in class io.servicetalk.concurrent.api.ExecutorRule
-
- newServiceFromRoutes(GrpcRoutes.AllGrpcRoutes) - Method in class io.servicetalk.grpc.api.GrpcRoutes
-
- newSignalOffloader(Executor) - Method in class io.servicetalk.concurrent.api.internal.OffloaderAwareExecutor
-
- newSignalOffloader(Executor) - Method in class io.servicetalk.concurrent.internal.DelegatingSignalOffloaderFactory
-
- newSignalOffloader(Executor) - Method in interface io.servicetalk.concurrent.internal.SignalOffloaderFactory
-
- newSingleController(Publisher<? extends ConsumableEvent<Integer>>, Completable) - Static method in class io.servicetalk.client.api.internal.RequestConcurrencyControllers
-
- newSingleController(Publisher<? extends ConsumableEvent<Integer>>, Completable) - Static method in class io.servicetalk.client.api.internal.ReservableRequestConcurrencyControllers
-
- newSingleProcessor() - Static method in class io.servicetalk.concurrent.api.Processors
-
Create a new SingleSource.Processor
that allows for multiple
subscribes
.
- newSpanContext(InMemoryTraceState) - Method in class io.servicetalk.opentracing.inmemory.DefaultInMemoryTracer
-
- newSpscQueue(int) - Static method in class io.servicetalk.utils.internal.PlatformDependent
-
Create a new Queue
which is safe to use for single producer (one thread!) and a single
consumer (one thread!).
- newSpscQueue(int, int) - Static method in class io.servicetalk.utils.internal.PlatformDependent
-
Create a new Queue
which is safe to use for single producer (one thread!) and a single
consumer (one thread!).
- newState() - Method in class io.servicetalk.http.api.StatelessTrailersTransformer
-
- newState() - Method in interface io.servicetalk.http.api.TrailersTransformer
-
Creates a new instance of the State
.
- newStrategy(Executor) - Method in class io.servicetalk.client.api.AbstractRetryingFilterBuilder.ReadOnlyRetryableSettings
-
- newStrategy(Publisher<Object>, Completable) - Method in interface io.servicetalk.client.api.AutoRetryStrategyProvider
-
- newStrategy(Publisher<Object>, Completable) - Method in class io.servicetalk.client.api.DefaultAutoRetryStrategyProvider
-
- newStreamingCall(GrpcSerializationProvider, Class<Req>, Class<Resp>) - Method in interface io.servicetalk.grpc.api.GrpcClientCallFactory
-
- newTaskBasedOffloader(Executor) - Static method in class io.servicetalk.concurrent.internal.SignalOffloaders
-
Create a new instance of
SignalOffloader
using the passed
executor
that uses granular tasks for
sending signals.
- newThread(Runnable) - Method in class io.servicetalk.concurrent.api.DefaultThreadFactory
-
- newThread(Runnable) - Method in class io.servicetalk.transport.netty.internal.IoThreadFactory
-
- newThreadBasedOffloader(Executor) - Static method in class io.servicetalk.concurrent.internal.SignalOffloaders
-
Create a new instance of
SignalOffloader
using the passed
executor
that captures a thread for
its lifetime.
- newTrailers() - Method in class io.servicetalk.http.api.DefaultHttpHeadersFactory
-
- newTrailers() - Method in interface io.servicetalk.http.api.HttpHeadersFactory
-
- newTrailers() - Method in class io.servicetalk.http.netty.H2HeadersFactory
-
- newTransportRequest(HttpRequestMethod, String, HttpProtocolVersion, HttpHeaders, BufferAllocator, Publisher<Object>, HttpHeadersFactory) - Static method in class io.servicetalk.http.api.StreamingHttpRequests
-
- newTransportResponse(HttpResponseStatus, HttpProtocolVersion, HttpHeaders, BufferAllocator, Publisher<Object>, HttpHeadersFactory) - Static method in class io.servicetalk.http.api.StreamingHttpResponses
-
- newUnboundedLinkedMpscQueue() - Static method in class io.servicetalk.utils.internal.PlatformDependent
-
Create a new MPSC Queue
that will use a linked data structure and supports Collection.remove(Object)
.
- newUnboundedMpscQueue() - Static method in class io.servicetalk.utils.internal.PlatformDependent
-
Create a new Queue
which is safe to use for multiple producers (different threads) and a single
consumer (one thread!).
- newUnboundedMpscQueue(int) - Static method in class io.servicetalk.utils.internal.PlatformDependent
-
Create a new Queue
which is safe to use for multiple producers (different threads) and a single
consumer (one thread!).
- newUnboundedSpscQueue(int) - Static method in class io.servicetalk.utils.internal.PlatformDependent
-
Create a new unbounded Queue
which is safe to use for single producer (one thread!) and a single
consumer (one thread!).
- next(T) - Method in interface io.servicetalk.concurrent.BlockingIterable.Processor
-
- next(long, TimeUnit) - Method in interface io.servicetalk.concurrent.BlockingIterator
-
- next() - Method in interface io.servicetalk.concurrent.BlockingIterator
-
- next() - Method in interface io.servicetalk.dns.discovery.netty.DnsServerAddressStream
-
Retrieves the next DNS server address from the stream.
- next() - Method in class io.servicetalk.dns.discovery.netty.SingletonDnsServerAddresses
-
- next() - Method in class io.servicetalk.http.api.HeaderUtils.CookiesByNameIterator
-
- next() - Method in class io.servicetalk.http.api.HeaderUtils.CookiesIterator
-
- next() - Method in interface io.servicetalk.transport.netty.internal.EventLoopAwareNettyIoExecutor
-
- nextCancellable(Cancellable) - Method in class io.servicetalk.concurrent.internal.SequentialCancellable
-
- nextLeftOver(CloseableIterator<Buffer>) - Method in class io.servicetalk.concurrent.api.internal.CloseableIteratorBufferAsInputStream
-
- nextLeftOver(CloseableIterator<T>) - Method in class io.servicetalk.concurrent.internal.AbstractCloseableIteratorAsInputStream
-
Read the next element from the Iterator
.
- nioBufferCount() - Method in interface io.servicetalk.buffer.api.Buffer
-
Returns the maximum number of NIO ByteBuffer
s that consist this buffer.
- nioBufferCount() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- NO_CACHE - Static variable in class io.servicetalk.http.api.HttpHeaderValues
-
"no-cache"
- NO_CONTENT - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
204 No Content
- NO_PARENT_ID - Static variable in class io.servicetalk.opentracing.internal.TracingConstants
-
- NO_STORE - Static variable in class io.servicetalk.http.api.HttpHeaderValues
-
"no-store"
- NO_TRANSFORM - Static variable in class io.servicetalk.http.api.HttpHeaderValues
-
"no-transform"
- NoAvailableHostException - Exception in io.servicetalk.client.api
-
Thrown when no host is available but at least one is required.
- NoAvailableHostException(String) - Constructor for exception io.servicetalk.client.api.NoAvailableHostException
-
Creates a new instance.
- noContent() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- noContent() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- noContent() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- noMoreInteractions() - Method in class io.servicetalk.concurrent.api.LegacyMockedSingleListenerRule
-
Deprecated.
- NON_AUTHORITATIVE_INFORMATION - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
203 Non-Authoritative Information (since HTTP/1.1)
- nonAuthoritativeInformation() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- nonAuthoritativeInformation() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- nonAuthoritativeInformation() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- NONE - Static variable in class io.servicetalk.http.api.HttpHeaderValues
-
"none"
- NONE - Static variable in class io.servicetalk.http.api.HttpRequestMethod.Properties
-
- nonnullParentSpanIdHex() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpan
-
Returns the parent span ID in hex.
- NonResubscribeableCompletableSubscriberFunction - Class in io.servicetalk.concurrent.api
-
- NonResubscribeableCompletableSubscriberFunction() - Constructor for class io.servicetalk.concurrent.api.NonResubscribeableCompletableSubscriberFunction
-
- NonResubscribeablePublisherSubscriberFunction<T> - Class in io.servicetalk.concurrent.api
-
- NonResubscribeablePublisherSubscriberFunction() - Constructor for class io.servicetalk.concurrent.api.NonResubscribeablePublisherSubscriberFunction
-
- NonResubscribeableSingleSubscriberFunction<T> - Class in io.servicetalk.concurrent.api
-
- NonResubscribeableSingleSubscriberFunction() - Constructor for class io.servicetalk.concurrent.api.NonResubscribeableSingleSubscriberFunction
-
- noOffloadsIsSupported() - Method in class io.servicetalk.http.router.jersey.MixedModeResourceTest
-
- noOffloadsOverrideIsSupported() - Method in class io.servicetalk.http.router.jersey.MixedModeResourceTest
-
- NoOffloadsRouteExecutionStrategy - Annotation Type in io.servicetalk.router.api
-
A special
RouteExecutionStrategy
that indicates that a resource class or method needs to use a strategy that
does not offload user code using a different thread pool.
- noOffloadsStrategy() - Static method in class io.servicetalk.grpc.api.GrpcExecutionStrategies
-
- noOffloadsStrategy() - Static method in class io.servicetalk.http.api.HttpExecutionStrategies
-
- NoopWriteEventsListener - Class in io.servicetalk.transport.netty.internal
-
- NoopWriteEventsListener() - Constructor for class io.servicetalk.transport.netty.internal.NoopWriteEventsListener
-
- noPayloadRequest(HttpRequestMethod, String) - Method in class io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest
-
- NOT_ACCEPTABLE - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
406 Not Acceptable
- NOT_EXTENDED - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
510 Not Extended
- NOT_FOUND - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
404 Not Found
- NOT_IMPLEMENTED - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
501 Not Implemented
- NOT_MODIFIED - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
304 Not Modified
- notAcceptable() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- notAcceptable() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- notAcceptable() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- notExtended() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- notExtended() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- notExtended() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- notFound() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- notFound() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- notFound() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- notFound() - Method in class io.servicetalk.http.router.jersey.AbstractResourceTest
-
- notImplemented() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- notImplemented() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- notImplemented() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- notModified() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- notModified() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- notModified() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- notTranslatedException() - Method in class io.servicetalk.http.router.jersey.AbstractResourceTest
-
- nUnavailable() - Method in interface io.servicetalk.dns.discovery.netty.DnsServiceDiscovererObserver.ResolutionResult
-
- objectsByCategory(PathSegment, List<String>) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- observer(DnsServiceDiscovererObserver) - Method in class io.servicetalk.dns.discovery.netty.DefaultDnsServiceDiscovererBuilder
-
- of(Status) - Static method in exception io.servicetalk.grpc.api.GrpcStatusException
-
- of(int, int) - Static method in class io.servicetalk.http.api.HttpProtocolVersion
-
- of(String, HttpRequestMethod.Properties) - Static method in class io.servicetalk.http.api.HttpRequestMethod
-
- of(String) - Static method in class io.servicetalk.http.api.HttpRequestMethod
-
- of(int, String) - Static method in class io.servicetalk.http.api.HttpResponseStatus
-
- of(CharSequence) - Static method in class io.servicetalk.http.api.HttpResponseStatus
-
- of(String) - Static method in interface io.servicetalk.opentracing.inmemory.SingleLineValue
-
- of(String, int) - Static method in interface io.servicetalk.transport.api.HostAndPort
-
- of(InetSocketAddress) - Static method in interface io.servicetalk.transport.api.HostAndPort
-
- offloadAll() - Method in class io.servicetalk.grpc.api.GrpcExecutionStrategies.Builder
-
Enable all offloads.
- offloadAll() - Method in class io.servicetalk.http.api.HttpExecutionStrategies.Builder
-
Enable all offloads.
- offloadCancellable(SingleSource.Subscriber<? super T>) - Method in class io.servicetalk.concurrent.internal.DelegatingSignalOffloader
-
- offloadCancellable(CompletableSource.Subscriber) - Method in class io.servicetalk.concurrent.internal.DelegatingSignalOffloader
-
- offloadCancellable(SingleSource.Subscriber<? super T>) - Method in interface io.servicetalk.concurrent.internal.SignalOffloader
-
Decorates the passed
SingleSource.Subscriber
such that all method calls to its
Cancellable
will
be offloaded.
- offloadCancellable(CompletableSource.Subscriber) - Method in interface io.servicetalk.concurrent.internal.SignalOffloader
-
Decorates the passed
CompletableSource.Subscriber
such that all method calls to its
Cancellable
will be offloaded.
- OffloaderAwareExecutor - Class in io.servicetalk.concurrent.api.internal
-
- OffloaderAwareExecutor(Executor, SignalOffloaderFactory) - Constructor for class io.servicetalk.concurrent.api.internal.OffloaderAwareExecutor
-
New instance.
- offloadNone() - Method in class io.servicetalk.grpc.api.GrpcExecutionStrategies.Builder
-
Disable all offloads.
- offloadNone() - Method in class io.servicetalk.http.api.HttpExecutionStrategies.Builder
-
Disable all offloads.
- offloadReceive(Executor, Single<T>) - Method in class io.servicetalk.http.api.DelegatingHttpExecutionStrategy
-
- offloadReceive(Executor, Publisher<T>) - Method in class io.servicetalk.http.api.DelegatingHttpExecutionStrategy
-
- offloadReceive(Executor, Single<T>) - Method in interface io.servicetalk.transport.api.ExecutionStrategy
-
Offloads the
original
Single
for receiving data from the transport.
- offloadReceive(Executor, Publisher<T>) - Method in interface io.servicetalk.transport.api.ExecutionStrategy
-
Offloads the
original
Publisher
for receiving data from the transport.
- offloadReceiveData() - Method in class io.servicetalk.grpc.api.GrpcExecutionStrategies.Builder
-
Enables offloading for receiving of data.
- offloadReceiveData() - Method in class io.servicetalk.http.api.HttpExecutionStrategies.Builder
-
Enables offloading for receiving of data.
- offloadReceiveMetadata() - Method in class io.servicetalk.grpc.api.GrpcExecutionStrategies.Builder
-
Enables offloading for receiving of metadata.
- offloadReceiveMetadata() - Method in class io.servicetalk.http.api.HttpExecutionStrategies.Builder
-
Enables offloading for receiving of metadata.
- offloadSend() - Method in class io.servicetalk.grpc.api.GrpcExecutionStrategies.Builder
-
Enables offloading for sending.
- offloadSend(Executor, Single<T>) - Method in class io.servicetalk.http.api.DelegatingHttpExecutionStrategy
-
- offloadSend(Executor, Publisher<T>) - Method in class io.servicetalk.http.api.DelegatingHttpExecutionStrategy
-
- offloadSend() - Method in class io.servicetalk.http.api.HttpExecutionStrategies.Builder
-
Enables offloading for sending.
- offloadSend(Executor, Single<T>) - Method in interface io.servicetalk.transport.api.ExecutionStrategy
-
Offloads the
original
Single
for sending data on the transport.
- offloadSend(Executor, Publisher<T>) - Method in interface io.servicetalk.transport.api.ExecutionStrategy
-
Offloads the
original
Publisher
for sending data on the transport.
- offloadService(Executor, StreamingHttpService) - Method in class io.servicetalk.http.api.DelegatingHttpExecutionStrategy
-
- offloadService(Executor, StreamingHttpService) - Method in interface io.servicetalk.http.api.HttpExecutionStrategy
-
- offloadSignal(T, Consumer<T>) - Method in class io.servicetalk.concurrent.internal.DelegatingSignalOffloader
-
- offloadSignal(T, Consumer<T>) - Method in interface io.servicetalk.concurrent.internal.SignalOffloader
-
Offloads the consumption of the passed signal
by the passed Consumer
.
- offloadSourcePublisher(HttpExecutionStrategy, Executor) - Method in class io.servicetalk.http.router.jersey.internal.BufferPublisherInputStream
-
- offloadSubscribe(PublisherSource.Subscriber<? super T>, Consumer<PublisherSource.Subscriber<? super T>>) - Method in class io.servicetalk.concurrent.internal.DelegatingSignalOffloader
-
- offloadSubscribe(SingleSource.Subscriber<? super T>, Consumer<SingleSource.Subscriber<? super T>>) - Method in class io.servicetalk.concurrent.internal.DelegatingSignalOffloader
-
- offloadSubscribe(CompletableSource.Subscriber, Consumer<CompletableSource.Subscriber>) - Method in class io.servicetalk.concurrent.internal.DelegatingSignalOffloader
-
- offloadSubscribe(PublisherSource.Subscriber<? super T>, Consumer<PublisherSource.Subscriber<? super T>>) - Method in interface io.servicetalk.concurrent.internal.SignalOffloader
-
- offloadSubscribe(SingleSource.Subscriber<? super T>, Consumer<SingleSource.Subscriber<? super T>>) - Method in interface io.servicetalk.concurrent.internal.SignalOffloader
-
- offloadSubscribe(CompletableSource.Subscriber, Consumer<CompletableSource.Subscriber>) - Method in interface io.servicetalk.concurrent.internal.SignalOffloader
-
- offloadSubscriber(PublisherSource.Subscriber<? super T>) - Method in class io.servicetalk.concurrent.internal.DelegatingSignalOffloader
-
- offloadSubscriber(SingleSource.Subscriber<? super T>) - Method in class io.servicetalk.concurrent.internal.DelegatingSignalOffloader
-
- offloadSubscriber(CompletableSource.Subscriber) - Method in class io.servicetalk.concurrent.internal.DelegatingSignalOffloader
-
- offloadSubscriber(PublisherSource.Subscriber<? super T>) - Method in interface io.servicetalk.concurrent.internal.SignalOffloader
-
- offloadSubscriber(SingleSource.Subscriber<? super T>) - Method in interface io.servicetalk.concurrent.internal.SignalOffloader
-
Decorates the passed SingleSource.Subscriber
such that all method calls to it will be offloaded.
- offloadSubscriber(CompletableSource.Subscriber) - Method in interface io.servicetalk.concurrent.internal.SignalOffloader
-
Decorates the passed CompletableSource.Subscriber
such that all method calls to it will be offloaded.
- offloadSubscription(PublisherSource.Subscriber<? super T>) - Method in class io.servicetalk.concurrent.internal.DelegatingSignalOffloader
-
- offloadSubscription(PublisherSource.Subscriber<? super T>) - Method in interface io.servicetalk.concurrent.internal.SignalOffloader
-
- offloadWithThreadAffinity() - Method in class io.servicetalk.grpc.api.GrpcExecutionStrategies.Builder
-
Enable thread affinity while offloading.
- offloadWithThreadAffinity() - Method in class io.servicetalk.http.api.HttpExecutionStrategies.Builder
-
Enable thread affinity while offloading.
- oioStreamsResource() - Method in class io.servicetalk.http.router.jersey.AbstractFilterInterceptorTest
-
- ok() - Static method in interface io.servicetalk.http.api.AbstractHttpRequesterFilterTest.RequestHandler
-
Default OK response handler.
- ok() - Static method in interface io.servicetalk.http.api.AbstractHttpRequesterFilterTest.RequestWithContextHandler
-
Default OK response handler.
- ok() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- ok() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- OK - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
200 OK
- ok() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- onClose() - Method in class io.servicetalk.client.api.DelegatingConnectionFactory
-
- onClose() - Method in class io.servicetalk.client.api.internal.DefaultPartitionedClientGroup
-
- onClose() - Method in class io.servicetalk.client.api.internal.partition.PowerSetPartitionMap
-
- onClose() - Method in class io.servicetalk.concurrent.api.DelegatingExecutor
-
- onClose() - Method in class io.servicetalk.concurrent.api.internal.OffloaderAwareExecutor
-
- onClose() - Method in interface io.servicetalk.concurrent.api.ListenableAsyncCloseable
-
- onClose() - Method in class io.servicetalk.concurrent.api.TestExecutor
-
- onClose() - Method in class io.servicetalk.http.api.DelegatingHttpServiceContext
-
- onClose() - Method in class io.servicetalk.http.api.ReservedStreamingHttpConnectionFilter
-
- onClose() - Method in class io.servicetalk.http.api.StreamingHttpClientFilter
-
- onClose() - Method in class io.servicetalk.http.api.StreamingHttpConnectionFilter
-
- onClose() - Method in class io.servicetalk.http.api.TestHttpServiceContext
-
- onClose() - Method in class io.servicetalk.loadbalancer.RoundRobinLoadBalancer
-
- onClose() - Method in class io.servicetalk.transport.api.DelegatingConnectionContext
-
- onClose() - Method in class io.servicetalk.transport.netty.internal.ChannelSet
-
- onClose() - Method in class io.servicetalk.transport.netty.internal.NettyChannelListenableAsyncCloseable
-
- onClose() - Method in class io.servicetalk.transport.netty.internal.NettyServerContext
-
- onClosing() - Method in class io.servicetalk.transport.netty.internal.DefaultNettyConnection
-
- onClosing() - Method in interface io.servicetalk.transport.netty.internal.NettyConnectionContext
-
Returns a
Completable
that notifies when the connection has begun its closing sequence.
- onComplete() - Method in class io.servicetalk.client.servicediscoverer.ServiceDiscovererTestSubscriber
-
- onComplete() - Method in class io.servicetalk.concurrent.api.DemandCheckingSubscriber
-
- onComplete() - Method in class io.servicetalk.concurrent.api.LegacyTestCompletable
-
Deprecated.
- onComplete() - Method in class io.servicetalk.concurrent.api.LoggingCompletableSubscriber
-
- onComplete() - Method in class io.servicetalk.concurrent.api.LoggingPublisherSubscriber
-
- onComplete() - Method in interface io.servicetalk.concurrent.api.TerminalSignalConsumer
-
Callback to indicate termination via PublisherSource.Subscriber#onComplete()
or
CompletableSource.Subscriber#onComplete()
.
- onComplete() - Method in class io.servicetalk.concurrent.api.TestCollectingCompletableSubscriber
-
- onComplete() - Method in class io.servicetalk.concurrent.api.TestCollectingPublisherSubscriber
-
- onComplete() - Method in class io.servicetalk.concurrent.api.TestCompletable
-
Completes the Subscriber
.
- onComplete() - Method in class io.servicetalk.concurrent.api.TestCompletableSubscriber
-
- onComplete() - Method in class io.servicetalk.concurrent.api.TestPublisher
-
Completes the Subscriber
.
- onComplete() - Method in class io.servicetalk.concurrent.api.TestPublisherSubscriber
-
- onComplete() - Method in interface io.servicetalk.concurrent.CompletableSource.Subscriber
-
Success terminal state.
- onComplete() - Method in class io.servicetalk.concurrent.internal.ConcurrentTerminalSubscriber
-
- onComplete() - Method in class io.servicetalk.concurrent.internal.LatestValueSubscriber
-
- onComplete() - Method in interface io.servicetalk.concurrent.PublisherSource.Subscriber
-
- onConnectionClose(ResolvedAddress) - Method in interface io.servicetalk.client.api.LimitingConnectionFactoryFilter.ConnectionLimiter
-
- onError(Throwable) - Method in class io.servicetalk.client.servicediscoverer.ServiceDiscovererTestSubscriber
-
- onError(Throwable) - Method in class io.servicetalk.concurrent.api.DemandCheckingSubscriber
-
- onError(Throwable) - Method in class io.servicetalk.concurrent.api.LegacyTestCompletable
-
Deprecated.
- onError(Throwable) - Method in class io.servicetalk.concurrent.api.LegacyTestSingle
-
Deprecated.
- onError(Throwable) - Method in class io.servicetalk.concurrent.api.LoggingCompletableSubscriber
-
- onError(Throwable) - Method in class io.servicetalk.concurrent.api.LoggingPublisherSubscriber
-
- onError(Throwable) - Method in class io.servicetalk.concurrent.api.LoggingSingleSubscriber
-
- onError(Throwable) - Method in interface io.servicetalk.concurrent.api.SingleTerminalSignalConsumer
-
Callback to indicate termination via SingleSource.Subscriber#onError(Throwable)
.
- onError(Throwable) - Method in interface io.servicetalk.concurrent.api.TerminalSignalConsumer
-
Callback to indicate termination via PublisherSource.Subscriber#onError(Throwable)
or
CompletableSource.Subscriber#onError(Throwable)
.
- onError(Throwable) - Method in class io.servicetalk.concurrent.api.TestCollectingCompletableSubscriber
-
- onError(Throwable) - Method in class io.servicetalk.concurrent.api.TestCollectingPublisherSubscriber
-
- onError(Throwable) - Method in class io.servicetalk.concurrent.api.TestCompletable
-
Delivers the Throwable
t
to the Subscriber
.
- onError(Throwable) - Method in class io.servicetalk.concurrent.api.TestCompletableSubscriber
-
- onError(Throwable) - Method in class io.servicetalk.concurrent.api.TestPublisher
-
Delivers the Throwable
t
to the Subscriber
.
- onError(Throwable) - Method in class io.servicetalk.concurrent.api.TestPublisherSubscriber
-
- onError(Throwable) - Method in class io.servicetalk.concurrent.api.TestSingle
-
Delivers the Throwable
t
to the Subscriber
.
- onError(Throwable) - Method in class io.servicetalk.concurrent.api.TestSingleSubscriber
-
- onError(Throwable) - Method in interface io.servicetalk.concurrent.CompletableSource.Subscriber
-
Failed terminal state.
- onError(Throwable) - Method in class io.servicetalk.concurrent.internal.ConcurrentTerminalSubscriber
-
- onError(Throwable) - Method in class io.servicetalk.concurrent.internal.LatestValueSubscriber
-
- onError(Throwable) - Method in interface io.servicetalk.concurrent.PublisherSource.Subscriber
-
Callback to receive an error
for this Subscriber
.
- onError(Throwable) - Method in interface io.servicetalk.concurrent.SingleSource.Subscriber
-
Failed terminal state.
- onErrorResume(Function<Throwable, ? extends Completable>) - Method in class io.servicetalk.concurrent.api.Completable
-
Recover from any error emitted by this
Completable
by using another
Completable
provided by the
passed
nextFactory
.
- onEventLogged(InMemorySpan, long, String) - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpanEventListener
-
Called when an event was logged.
- onEventLogged(InMemorySpan, long, Map<String, ?>) - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpanEventListener
-
Called when an event was logged.
- onEventLogged(InMemorySpan, long, String) - Method in class io.servicetalk.opentracing.zipkin.publisher.ZipkinPublisher
-
- onEventLogged(InMemorySpan, long, Map<String, ?>) - Method in class io.servicetalk.opentracing.zipkin.publisher.ZipkinPublisher
-
- onItemWrite(Object, long, long) - Method in interface io.servicetalk.transport.netty.internal.WriteDemandEstimator
-
Callback whenever an item is written on the connection.
- ONLY_IF_CACHED - Static variable in class io.servicetalk.http.api.HttpHeaderValues
-
"only-if-cached"
- onNewDiscovery(String) - Method in interface io.servicetalk.dns.discovery.netty.DnsServiceDiscovererObserver
-
- onNewResolution(String) - Method in interface io.servicetalk.dns.discovery.netty.DnsServiceDiscovererObserver.DnsDiscoveryObserver
-
Notifies that a new DNS resolution started.
- onNext(ServiceDiscovererEvent<T>) - Method in class io.servicetalk.client.servicediscoverer.ServiceDiscovererTestSubscriber
-
- onNext(T) - Method in class io.servicetalk.concurrent.api.DemandCheckingSubscriber
-
- onNext(T) - Method in class io.servicetalk.concurrent.api.LoggingPublisherSubscriber
-
- onNext(T) - Method in class io.servicetalk.concurrent.api.TestCollectingPublisherSubscriber
-
- onNext(T...) - Method in class io.servicetalk.concurrent.api.TestPublisher
-
Delivers the items
, one at a time, to the Subscriber
.
- onNext(T) - Method in class io.servicetalk.concurrent.api.TestPublisherSubscriber
-
- onNext(T) - Method in class io.servicetalk.concurrent.internal.ConcurrentTerminalSubscriber
-
- onNext(T) - Method in class io.servicetalk.concurrent.internal.LatestValueSubscriber
-
- onNext(T) - Method in interface io.servicetalk.concurrent.PublisherSource.Subscriber
-
Callback to receive a data
element for this Subscriber
.
- onSpanFinished(InMemorySpan, long) - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpanEventListener
-
Called when a span has finished.
- onSpanFinished(InMemorySpan, long) - Method in class io.servicetalk.opentracing.zipkin.publisher.ZipkinPublisher
-
Converts a finished
InMemorySpan
to a
Span
and passes it to the
Reporter.report(Object)
.
- onSpanStarted(InMemorySpan) - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpanEventListener
-
Called when a span has started.
- onSpanStarted(InMemorySpan) - Method in class io.servicetalk.opentracing.zipkin.publisher.ZipkinPublisher
-
- onSubscribe(PublisherSource.Subscription) - Method in class io.servicetalk.client.servicediscoverer.ServiceDiscovererTestSubscriber
-
- onSubscribe(PublisherSource.Subscription) - Method in class io.servicetalk.concurrent.api.DemandCheckingSubscriber
-
- onSubscribe(Cancellable) - Method in class io.servicetalk.concurrent.api.LegacyTestCompletable
-
Deprecated.
- onSubscribe(Cancellable) - Method in class io.servicetalk.concurrent.api.LegacyTestSingle
-
Deprecated.
- onSubscribe(Cancellable) - Method in class io.servicetalk.concurrent.api.LoggingCompletableSubscriber
-
- onSubscribe(PublisherSource.Subscription) - Method in class io.servicetalk.concurrent.api.LoggingPublisherSubscriber
-
- onSubscribe(Cancellable) - Method in class io.servicetalk.concurrent.api.LoggingSingleSubscriber
-
- onSubscribe(Cancellable) - Method in class io.servicetalk.concurrent.api.TestCollectingCompletableSubscriber
-
- onSubscribe(PublisherSource.Subscription) - Method in class io.servicetalk.concurrent.api.TestCollectingPublisherSubscriber
-
- onSubscribe(Cancellable) - Method in class io.servicetalk.concurrent.api.TestCompletable
-
Delivers the
Cancellable
to the
Subscriber
's
Subscriber#onSubscribe(Cancellable)
.
- onSubscribe(Cancellable) - Method in class io.servicetalk.concurrent.api.TestCompletableSubscriber
-
- onSubscribe(PublisherSource.Subscription) - Method in class io.servicetalk.concurrent.api.TestPublisher
-
Delivers the Subscription
to the Subscriber
's Subscriber#onSubscribe(Subscription)
.
- onSubscribe(PublisherSource.Subscription) - Method in class io.servicetalk.concurrent.api.TestPublisherSubscriber
-
- onSubscribe(Cancellable) - Method in class io.servicetalk.concurrent.api.TestSingle
-
Delivers the
Cancellable
to the
Subscriber
's
Subscriber#onSubscribe(Cancellable)
.
- onSubscribe(Cancellable) - Method in class io.servicetalk.concurrent.api.TestSingleSubscriber
-
- onSubscribe(Cancellable) - Method in interface io.servicetalk.concurrent.CompletableSource.Subscriber
-
- onSubscribe(PublisherSource.Subscription) - Method in class io.servicetalk.concurrent.internal.ConcurrentTerminalSubscriber
-
- onSubscribe(PublisherSource.Subscription) - Method in class io.servicetalk.concurrent.internal.LatestValueSubscriber
-
- onSubscribe(PublisherSource.Subscription) - Method in interface io.servicetalk.concurrent.PublisherSource.Subscriber
-
- onSubscribe(Cancellable) - Method in interface io.servicetalk.concurrent.SingleSource.Subscriber
-
- onSuccess(T) - Method in class io.servicetalk.concurrent.api.LegacyTestSingle
-
Deprecated.
- onSuccess(T) - Method in class io.servicetalk.concurrent.api.LoggingSingleSubscriber
-
- onSuccess(T) - Method in interface io.servicetalk.concurrent.api.SingleTerminalSignalConsumer
-
Callback to indicate termination via SingleSource.Subscriber#onSuccess(Object)
.
- onSuccess(T) - Method in class io.servicetalk.concurrent.api.TestSingle
-
Delivers the result
to the Subscriber
.
- onSuccess(T) - Method in class io.servicetalk.concurrent.api.TestSingleSubscriber
-
- onSuccess(T) - Method in interface io.servicetalk.concurrent.SingleSource.Subscriber
-
Success terminal state.
- operationName() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpan
-
Returns the operation name.
- options(String) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequestFactory
-
- options(String) - Method in interface io.servicetalk.http.api.HttpRequestFactory
-
- OPTIONS - Static variable in class io.servicetalk.http.api.HttpRequestMethod
-
- options(String) - Method in interface io.servicetalk.http.api.StreamingHttpRequestFactory
-
- options(String) - Method in class io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest
-
- optResourceEnabled(boolean) - Method in class io.servicetalk.dns.discovery.netty.DefaultDnsServiceDiscovererBuilder
-
Enable the automatic inclusion of a optional records that tries to give the remote DNS server a hint about
how much data the resolver can read per response.
- ORIGIN - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"origin"
- PARENT_SPAN_ID - Static variable in class io.servicetalk.opentracing.internal.ZipkinHeaderNames
-
- parentSpanId() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpan
-
Returns the parent span ID, could be null.
- parentSpanIdHex() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemoryTraceState
-
The hex representation of the parent's spanId.
- parentSpanIdHex() - Method in class io.servicetalk.opentracing.inmemory.DefaultInMemoryTraceState
-
- parseCookiePair(CharSequence, int, int) - Static method in class io.servicetalk.http.api.DefaultHttpCookiePair
-
- parseCookiePair(CharSequence, int, int, int) - Static method in class io.servicetalk.http.api.DefaultHttpCookiePair
-
- parseCookiePair(CharSequence, CharSequence) - Static method in class io.servicetalk.http.api.HeaderUtils
-
- parseSetCookie(CharSequence, boolean) - Static method in class io.servicetalk.http.api.DefaultHttpSetCookie
-
- parseSetCookie(CharSequence, CharSequence, boolean) - Static method in class io.servicetalk.http.api.HeaderUtils
-
- PARTIAL_CONTENT - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
206 Partial Content
- partialContent() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- partialContent() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- partialContent() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- partitionAddress() - Method in interface io.servicetalk.client.api.partition.PartitionedServiceDiscovererEvent
-
- PartitionAttributes - Interface in io.servicetalk.client.api.partition
-
Provide a way to describe a partition using a collection of of attributes.
- PartitionAttributes.Key<T> - Class in io.servicetalk.client.api.partition
-
- PartitionAttributesBuilder - Interface in io.servicetalk.client.api.partition
-
- PartitionedHttpClientBuilder<U,R> - Class in io.servicetalk.http.api
-
- PartitionedHttpClientBuilder() - Constructor for class io.servicetalk.http.api.PartitionedHttpClientBuilder
-
- PartitionedHttpClientSecurityConfigurator<U,R> - Interface in io.servicetalk.http.api
-
- PartitionedServiceDiscovererEvent<ResolvedAddress> - Interface in io.servicetalk.client.api.partition
-
- PartitionHttpClientBuilderConfigurator<U,R> - Interface in io.servicetalk.http.api
-
If different clients used by a partitioned client created by a
PartitionedHttpClientBuilder
have different
builder configuration, this configurator helps to configure them differently.
- PartitionMap<T extends AsyncCloseable> - Interface in io.servicetalk.client.api.partition
-
- PartitionMapFactory - Interface in io.servicetalk.client.api.partition
-
- partitionMapFactory(PartitionMapFactory) - Method in class io.servicetalk.http.api.PartitionedHttpClientBuilder
-
- patch(String) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequestFactory
-
- patch(String) - Method in interface io.servicetalk.http.api.HttpRequestFactory
-
- PATCH - Static variable in class io.servicetalk.http.api.HttpRequestMethod
-
- patch(String) - Method in interface io.servicetalk.http.api.StreamingHttpRequestFactory
-
- path() - Method in interface io.servicetalk.grpc.api.GrpcMetadata
-
Returns the path for the associated
gRPC method.
- path(String) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- path() - Method in class io.servicetalk.http.api.DefaultHttpSetCookie
-
- path(String) - Method in interface io.servicetalk.http.api.HttpRequest
-
- path() - Method in interface io.servicetalk.http.api.HttpRequestMetaData
-
- path(String) - Method in interface io.servicetalk.http.api.HttpRequestMetaData
-
Sets the path, performing encoding according
to
percent-encoding, except for forward-slash
(
'/'
) characters.
- path() - Method in interface io.servicetalk.http.api.HttpSetCookie
-
- path(String) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- PATH - Static variable in class io.servicetalk.http.router.jersey.resources.AsynchronousResources
-
- PATH - Static variable in class io.servicetalk.http.router.jersey.resources.CancellableResources
-
- PATH - Static variable in class io.servicetalk.http.router.jersey.resources.MixedModeResources
-
- PATH - Static variable in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- pathMatches(CharSequence, CharSequence) - Static method in class io.servicetalk.http.api.HeaderUtils
-
- pathParams() - Method in class io.servicetalk.http.router.jersey.SynchronousResourceTest
-
- PAYLOAD_TOO_LARGE - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
413 Payload Too Large
- payloadBody() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- payloadBody(HttpDeserializer<T>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
Gets and deserializes the payload body.
- payloadBody(Iterable<Buffer>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- payloadBody(CloseableIterable<Buffer>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- payloadBody(Iterable<T>, HttpSerializer<T>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- payloadBody(CloseableIterable<T>, HttpSerializer<T>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- payloadBody() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
- payloadBody(HttpDeserializer<T>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
Gets and deserializes the payload body.
- payloadBody(Iterable<Buffer>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
- payloadBody(CloseableIterable<Buffer>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
- payloadBody(Iterable<T>, HttpSerializer<T>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
- payloadBody(CloseableIterable<T>, HttpSerializer<T>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
- payloadBody() - Method in interface io.servicetalk.http.api.HttpRequest
-
Gets the underlying payload as a
Buffer
.
- payloadBody(HttpDeserializer<T>) - Method in interface io.servicetalk.http.api.HttpRequest
-
Gets and deserializes the payload body.
- payloadBody(Buffer) - Method in interface io.servicetalk.http.api.HttpRequest
-
Returns an
HttpRequest
with its underlying payload set to
payloadBody
.
- payloadBody(T, HttpSerializer<T>) - Method in interface io.servicetalk.http.api.HttpRequest
-
Returns an
HttpRequest
with its underlying payload set to the results of serialization of
pojo
.
- payloadBody() - Method in interface io.servicetalk.http.api.HttpResponse
-
Gets the underlying payload as a
Buffer
.
- payloadBody(HttpDeserializer<T>) - Method in interface io.servicetalk.http.api.HttpResponse
-
Gets and deserializes the payload body.
- payloadBody(Buffer) - Method in interface io.servicetalk.http.api.HttpResponse
-
Returns an
HttpResponse
with its underlying payload set to
payloadBody
.
- payloadBody(T, HttpSerializer<T>) - Method in interface io.servicetalk.http.api.HttpResponse
-
Returns an
HttpResponse
with its underlying payload set to the results of serialization of
pojo
.
- payloadBody() - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- payloadBody(HttpDeserializer<T>) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
Gets and deserializes the payload body.
- payloadBody(Publisher<Buffer>) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- payloadBody(Publisher<T>, HttpSerializer<T>) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- payloadBody() - Method in interface io.servicetalk.http.api.StreamingHttpResponse
-
- payloadBody(HttpDeserializer<T>) - Method in interface io.servicetalk.http.api.StreamingHttpResponse
-
Gets and deserializes the payload body.
- payloadBody(Publisher<Buffer>) - Method in interface io.servicetalk.http.api.StreamingHttpResponse
-
- payloadBody(Publisher<T>, HttpSerializer<T>) - Method in interface io.servicetalk.http.api.StreamingHttpResponse
-
- payloadBodyAndTrailers() - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- payloadBodyAndTrailers() - Method in interface io.servicetalk.http.api.StreamingHttpResponse
-
- payloadBodyInputStream() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
Gets the underlying payload as a InputStream
.
- payloadBodyInputStream() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
Gets the underlying payload as a InputStream
.
- payloadComplete(Object, HttpHeaders) - Method in class io.servicetalk.http.api.StatelessTrailersTransformer
-
- payloadComplete(HttpHeaders) - Method in class io.servicetalk.http.api.StatelessTrailersTransformer
-
- payloadComplete(State, HttpHeaders) - Method in interface io.servicetalk.http.api.TrailersTransformer
-
Invoked once all
Payload
instances are
accepted
and the payload stream
has successfully completed.
- payloadFailed(Throwable, HttpHeaders) - Method in class io.servicetalk.http.api.StatelessTrailersTransformer
-
- payloadRequest(HttpRequestMethod, String, CharSequence, CharSequence) - Method in class io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest
-
- payloadTooLarge() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- payloadTooLarge() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- payloadTooLarge() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- PayloadWriter<T> - Interface in io.servicetalk.oio.api
-
An interface which mimics behavior like OutputStream
, but allows for writing of objects of type
T
.
- PAYMENT_REQUIRED - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
402 Payment Required
- paymentRequired() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- paymentRequired() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- paymentRequired() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- PERMANENT_REDIRECT - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
308 Permanent Redirect
- permanentRedirect() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- permanentRedirect() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- permanentRedirect() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- persistLogs(boolean) - Method in class io.servicetalk.opentracing.inmemory.DefaultInMemoryTracer.Builder
-
Sets whether logs are persisted in the span object.
- PlatformDependent - Class in io.servicetalk.utils.internal
-
Provide utilities that are dependent on the current runtime environment.
- pollAllOnNext() - Method in class io.servicetalk.concurrent.api.TestCollectingPublisherSubscriber
-
- pollTerminal(long, TimeUnit) - Method in class io.servicetalk.concurrent.api.TestCollectingCompletableSubscriber
-
Block for a terminal event.
- pollTerminal(long, TimeUnit) - Method in class io.servicetalk.concurrent.api.TestCollectingPublisherSubscriber
-
Block for a terminal event.
- POOLED_ALLOCATOR - Static variable in class io.servicetalk.transport.netty.internal.CopyByteBufHandlerChannelInitializer
-
PooledByteBufAllocator
to use internally when we know memory won't be leaked.
- port() - Method in interface io.servicetalk.http.api.HttpRequestMetaData
-
- port() - Method in interface io.servicetalk.transport.api.HostAndPort
-
Returns the port.
- post(String) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequestFactory
-
- post(String) - Method in interface io.servicetalk.http.api.HttpRequestFactory
-
- POST - Static variable in class io.servicetalk.http.api.HttpRequestMethod
-
- post(String) - Method in interface io.servicetalk.http.api.StreamingHttpRequestFactory
-
- post(String, CharSequence, CharSequence) - Method in class io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest
-
- postBadJson() - Method in class io.servicetalk.http.router.jersey.AbstractResourceTest
-
- postFiltered(String) - Method in class io.servicetalk.http.router.jersey.resources.AsynchronousResources
-
- postJson() - Method in class io.servicetalk.http.router.jersey.AbstractResourceTest
-
- postJson() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- postJson(Map<String, Object>) - Method in class io.servicetalk.http.router.jersey.resources.AsynchronousResources
-
- postJson(Map<String, Object>) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postJsonBuffer() - Method in class io.servicetalk.http.router.jersey.AbstractResourceTest
-
- postJsonBuffer() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- postJsonBuffer(Buffer) - Method in class io.servicetalk.http.router.jersey.resources.AsynchronousResources
-
- postJsonBuffer(Buffer) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postJsonBufPubInPubOut(Publisher<Buffer>) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postJsonBufPubInPubOut() - Method in class io.servicetalk.http.router.jersey.SynchronousResourceTest
-
- postJsonBufPubInPubOutResponse(Publisher<Buffer>) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postJsonBufPubInPubOutResponse() - Method in class io.servicetalk.http.router.jersey.SynchronousResourceTest
-
- postJsonBufSingleInSingleOut() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- postJsonBufSingleInSingleOut(boolean, Single<Buffer>) - Method in class io.servicetalk.http.router.jersey.resources.AsynchronousResources
-
- postJsonBufSingleInSingleOutResponse(Single<Buffer>) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postJsonBufSingleInSingleOutResponse() - Method in class io.servicetalk.http.router.jersey.SynchronousResourceTest
-
- postJsonBytes() - Method in class io.servicetalk.http.router.jersey.AbstractResourceTest
-
- postJsonBytes() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- postJsonBytes(byte[]) - Method in class io.servicetalk.http.router.jersey.resources.AsynchronousResources
-
- postJsonBytes(byte[]) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postJsonMapInPubOut(Map<String, Object>) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postJsonMapInPubOut() - Method in class io.servicetalk.http.router.jersey.SynchronousResourceTest
-
- postJsonOioStreams(InputStream) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postJsonOioStreams() - Method in class io.servicetalk.http.router.jersey.SynchronousResourceTest
-
- postJsonPojo(TestPojo) - Method in class io.servicetalk.http.router.jersey.resources.AsynchronousResources
-
- postJsonPojoInPojoOut() - Method in class io.servicetalk.http.router.jersey.AbstractResourceTest
-
- postJsonPojoInPojoOut() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- postJsonPojoInPojoOut(TestPojo) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postJsonPojoInPojoOutResponse(TestPojo) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postJsonPojoInPojoOutResponse() - Method in class io.servicetalk.http.router.jersey.SynchronousResourceTest
-
- postJsonPojoInPojoOutResponseSingle() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- postJsonPojoInPojoOutResponseSingle(boolean, TestPojo) - Method in class io.servicetalk.http.router.jersey.resources.AsynchronousResources
-
- postJsonPojoInPojoOutSingle() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- postJsonPojoInPojoOutSingle(boolean, TestPojo) - Method in class io.servicetalk.http.router.jersey.resources.AsynchronousResources
-
- postJsonPubInMapOut(Publisher<Buffer>) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postJsonPubInMapOut() - Method in class io.servicetalk.http.router.jersey.SynchronousResourceTest
-
- postJsonPubInPubOut(Publisher<Buffer>) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postJsonPubInPubOut() - Method in class io.servicetalk.http.router.jersey.SynchronousResourceTest
-
- postNoOffloadsOioStreams(InputStream) - Method in class io.servicetalk.http.router.jersey.resources.CancellableResources
-
- postNoOffloadsRsStreams(boolean, Publisher<Buffer>, ConnectionContext) - Method in class io.servicetalk.http.router.jersey.resources.CancellableResources
-
- postOffloadedOioStreams(InputStream) - Method in class io.servicetalk.http.router.jersey.resources.CancellableResources
-
- postOffloadedRsStreams(boolean, Publisher<Buffer>, ConnectionContext) - Method in class io.servicetalk.http.router.jersey.resources.CancellableResources
-
- postOioStreams(InputStream) - Method in class io.servicetalk.http.router.jersey.resources.CancellableResources
-
- postRsStreams(boolean, Publisher<Buffer>, ConnectionContext) - Method in class io.servicetalk.http.router.jersey.resources.CancellableResources
-
- postText() - Method in class io.servicetalk.http.router.jersey.AbstractResourceTest
-
- postText(String) - Method in class io.servicetalk.http.router.jersey.resources.AsynchronousResources
-
- postText(String) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postTextBuffer() - Method in class io.servicetalk.http.router.jersey.AbstractResourceTest
-
- postTextBuffer() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- postTextBuffer(Buffer) - Method in class io.servicetalk.http.router.jersey.resources.AsynchronousResources
-
- postTextBuffer(Buffer) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postTextBufferResponse() - Method in class io.servicetalk.http.router.jersey.AbstractResourceTest
-
- postTextBufferResponse() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- postTextBufferResponse(Buffer) - Method in class io.servicetalk.http.router.jersey.resources.AsynchronousResources
-
- postTextBufferResponse(Buffer) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postTextBytes() - Method in class io.servicetalk.http.router.jersey.AbstractResourceTest
-
- postTextBytes() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- postTextBytes(byte[]) - Method in class io.servicetalk.http.router.jersey.resources.AsynchronousResources
-
- postTextBytes(byte[]) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postTextNoEntity() - Method in class io.servicetalk.http.router.jersey.AbstractResourceTest
-
- postTextOioStreams(InputStream) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postTextOioStreams() - Method in class io.servicetalk.http.router.jersey.SynchronousResourceTest
-
- postTextPubInPubOut(Publisher<Buffer>) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postTextPubInPubOut() - Method in class io.servicetalk.http.router.jersey.SynchronousResourceTest
-
- postTextPubInStrOut(Publisher<Buffer>) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postTextPubInStrOut() - Method in class io.servicetalk.http.router.jersey.SynchronousResourceTest
-
- postTextResponse() - Method in class io.servicetalk.http.router.jersey.AbstractResourceTest
-
- postTextResponse() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- postTextResponse(String) - Method in class io.servicetalk.http.router.jersey.resources.AsynchronousResources
-
- postTextResponse(String) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postTextStrInPubOut(String) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- postTextStrInPubOut() - Method in class io.servicetalk.http.router.jersey.SynchronousResourceTest
-
- PowerSetPartitionMap<T extends AsyncCloseable> - Class in io.servicetalk.client.api.internal.partition
-
- PowerSetPartitionMap(Function<PartitionAttributes, T>, IntFunction<PartitionAttributesBuilder>) - Constructor for class io.servicetalk.client.api.internal.partition.PowerSetPartitionMap
-
Create a new instance.
- PowerSetPartitionMapFactory - Class in io.servicetalk.client.api.internal.partition
-
- PRAGMA - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"pragma"
- PRECONDITION_FAILED - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
412 Precondition Failed
- PRECONDITION_REQUIRED - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
428 Precondition Required
- preconditionFailed() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- preconditionFailed() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- preconditionFailed() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- preconditionRequired() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- preconditionRequired() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- preconditionRequired() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- PREFER_DIRECT_ALLOCATOR - Static variable in class io.servicetalk.buffer.netty.BufferAllocators
-
Default
BufferAllocator
whose
Buffer
s are typically backed by Netty buffers and prefers direct
memory allocation when otherwise not specified.
- PREFER_DIRECT_RO_ALLOCATOR - Static variable in class io.servicetalk.buffer.api.ReadOnlyBufferAllocators
-
BufferAllocator
that creates
Buffer
instances which prefer off-heap allocations when otherwise
unspecified which cannot be modified and are read only.
- PREFER_HEAP_ALLOCATOR - Static variable in class io.servicetalk.buffer.netty.BufferAllocators
-
Default
BufferAllocator
whose
Buffer
s are typically backed by Netty buffers and prefers heap
memory allocation when otherwise not specified.
- PREFER_HEAP_RO_ALLOCATOR - Static variable in class io.servicetalk.buffer.api.ReadOnlyBufferAllocators
-
BufferAllocator
that creates
Buffer
instances which prefer heap allocations when otherwise
unspecified which cannot be modified and are read only.
- prepend(T) - Method in interface io.servicetalk.concurrent.api.CompositeCloseable
-
- prepend(HttpExecutionStrategyInfluencer) - Method in class io.servicetalk.http.api.StrategyInfluencerChainBuilder
-
- prependAll(AsyncCloseable...) - Method in interface io.servicetalk.concurrent.api.CompositeCloseable
-
- prependAll(Iterable<? extends AsyncCloseable>) - Method in interface io.servicetalk.concurrent.api.CompositeCloseable
-
- prependIfInfluencer(Object) - Method in class io.servicetalk.http.api.StrategyInfluencerChainBuilder
-
- principalFunction(PF) - Method in class io.servicetalk.http.security.auth.basic.jersey.BasicAuthSecurityContextFilters.AbstractBuilder
-
Specify a custom function the filter will use to create Principal
instances.
- PRIVATE - Static variable in class io.servicetalk.http.api.HttpHeaderValues
-
"private"
- process(byte) - Method in interface io.servicetalk.buffer.api.ByteProcessor
-
Process bytes until returns false
.
- processing() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- processing() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- PROCESSING - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
102 Processing
- processing() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- processOnComplete() - Method in class io.servicetalk.concurrent.internal.ConcurrentTerminalSubscriber
-
- processOnError(Throwable) - Method in class io.servicetalk.concurrent.internal.ConcurrentTerminalSubscriber
-
- Processors - Class in io.servicetalk.concurrent.api
-
Static factory methods for creating processor instances for different type of sources.
- ProcessorSignalsConsumer<T> - Interface in io.servicetalk.concurrent.api
-
- properties() - Method in class io.servicetalk.http.api.HttpRequestMethod
-
- ProtobufSerializationProvider - Class in io.servicetalk.data.protobuf
-
- ProtobufSerializationProvider() - Constructor for class io.servicetalk.data.protobuf.ProtobufSerializationProvider
-
- ProtobufSerializationProvider(Function<Class<?>, Parser<?>>) - Constructor for class io.servicetalk.data.protobuf.ProtobufSerializationProvider
-
- ProtoBufSerializationProviderBuilder - Class in io.servicetalk.grpc.protobuf
-
- ProtoBufSerializationProviderBuilder() - Constructor for class io.servicetalk.grpc.protobuf.ProtoBufSerializationProviderBuilder
-
- protocol() - Method in interface io.servicetalk.grpc.api.GrpcServiceContext
-
- protocol() - Method in class io.servicetalk.http.api.DelegatingHttpConnectionContext
-
- protocol() - Method in class io.servicetalk.http.api.DelegatingHttpServiceContext
-
- protocol() - Method in interface io.servicetalk.http.api.HttpConnectionContext
-
- protocol() - Method in class io.servicetalk.http.api.TestHttpServiceContext
-
- protocol() - Method in interface io.servicetalk.transport.api.ConnectionContext
-
- protocol() - Method in class io.servicetalk.transport.api.DelegatingConnectionContext
-
- protocol() - Method in class io.servicetalk.transport.netty.internal.DefaultNettyConnection
-
- PROTOCOL_OUTBOUND_CLOSE_HANDLER - Static variable in class io.servicetalk.transport.netty.internal.CloseHandler
-
- protocolClosingInbound(ChannelHandlerContext) - Method in class io.servicetalk.transport.netty.internal.CloseHandler
-
Signal inbound close command observed, to be emitted from the EventLoop
for the Channel
.
- protocolClosingOutbound(ChannelHandlerContext) - Method in class io.servicetalk.transport.netty.internal.CloseHandler
-
Signal outbound close command observed, to be emitted from the EventLoop
for the Channel
.
- protocolPayloadBeginInbound(ChannelHandlerContext) - Method in class io.servicetalk.transport.netty.internal.CloseHandler
-
Signal begin of inbound payload, to be emitted from the EventLoop
for the Channel
.
- protocolPayloadBeginOutbound(ChannelHandlerContext) - Method in class io.servicetalk.transport.netty.internal.CloseHandler
-
Signal begin of outbound payload, to be emitted from the EventLoop
for the Channel
.
- protocolPayloadEndInbound(ChannelHandlerContext) - Method in class io.servicetalk.transport.netty.internal.CloseHandler
-
Signal end of inbound payload, to be emitted from the EventLoop
for the Channel
.
- protocolPayloadEndOutbound(ChannelHandlerContext) - Method in class io.servicetalk.transport.netty.internal.CloseHandler
-
Signal end of outbound payload, to be emitted from the EventLoop
for the Channel
.
- protocolPayloadEndOutboundSuccess(ChannelHandlerContext) - Method in class io.servicetalk.transport.netty.internal.CloseHandler
-
Signal end of outbound payload, once successfully written to the Channel
.
- protocols(HttpProtocolConfig...) - Method in class io.servicetalk.grpc.api.GrpcClientBuilder
-
- protocols(String...) - Method in interface io.servicetalk.grpc.api.GrpcClientSecurityConfigurator
-
- protocols(HttpProtocolConfig...) - Method in class io.servicetalk.grpc.api.GrpcServerBuilder
-
Configurations of various underlying protocol versions.
- protocols(String...) - Method in interface io.servicetalk.grpc.api.GrpcServerSecurityConfigurator
-
- protocols(HttpProtocolConfig...) - Method in class io.servicetalk.http.api.HttpServerBuilder
-
Configurations of various HTTP protocol versions.
- protocols(String...) - Method in interface io.servicetalk.http.api.HttpServerSecurityConfigurator
-
- protocols(HttpProtocolConfig...) - Method in class io.servicetalk.http.api.PartitionedHttpClientBuilder
-
- protocols(String...) - Method in interface io.servicetalk.http.api.PartitionedHttpClientSecurityConfigurator
-
- protocols(HttpProtocolConfig...) - Method in class io.servicetalk.http.api.SingleAddressHttpClientBuilder
-
- protocols(String...) - Method in interface io.servicetalk.http.api.SingleAddressHttpClientSecurityConfigurator
-
- protocols(String...) - Method in interface io.servicetalk.transport.api.ClientSecurityConfigurator
-
- protocols(String...) - Method in interface io.servicetalk.transport.api.SecurityConfigurator
-
The SSL protocols to enable, in the order of preference.
- protocols(String...) - Method in interface io.servicetalk.transport.api.ServerSecurityConfigurator
-
- protocols(String...) - Method in class io.servicetalk.transport.netty.internal.ClientSecurityConfig
-
The SSL protocols to enable, in the order of preference.
- protocols(String...) - Method in class io.servicetalk.transport.netty.internal.ServerSecurityConfig
-
The SSL protocols to enable, in the order of preference.
- provider(SecurityConfigurator.SslProvider) - Method in interface io.servicetalk.grpc.api.GrpcClientSecurityConfigurator
-
- provider(SecurityConfigurator.SslProvider) - Method in interface io.servicetalk.grpc.api.GrpcServerSecurityConfigurator
-
- provider(SecurityConfigurator.SslProvider) - Method in interface io.servicetalk.http.api.HttpServerSecurityConfigurator
-
- provider(SecurityConfigurator.SslProvider) - Method in interface io.servicetalk.http.api.PartitionedHttpClientSecurityConfigurator
-
- provider(SecurityConfigurator.SslProvider) - Method in interface io.servicetalk.http.api.SingleAddressHttpClientSecurityConfigurator
-
- provider(SecurityConfigurator.SslProvider) - Method in interface io.servicetalk.transport.api.ClientSecurityConfigurator
-
- provider(SecurityConfigurator.SslProvider) - Method in interface io.servicetalk.transport.api.SecurityConfigurator
-
- provider(SecurityConfigurator.SslProvider) - Method in interface io.servicetalk.transport.api.ServerSecurityConfigurator
-
- provider(SecurityConfigurator.SslProvider) - Method in class io.servicetalk.transport.netty.internal.ClientSecurityConfig
-
- provider(SecurityConfigurator.SslProvider) - Method in class io.servicetalk.transport.netty.internal.ServerSecurityConfig
-
- PROXY_AUTHENTICATE - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"proxy-authenticate"
- PROXY_AUTHENTICATION_REQUIRED - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
407 Proxy Authentication Required
- PROXY_AUTHORIZATION - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"proxy-authorization"
- PROXY_REVALIDATE - Static variable in class io.servicetalk.http.api.HttpHeaderValues
-
"proxy-revalidate"
- proxyAuthenticationRequired() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- proxyAuthenticationRequired() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- proxyAuthenticationRequired() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- ProxyResponseException - Exception in io.servicetalk.http.netty
-
A proxy response exception, that indicates an unexpected response status from a proxy.
- PUBLIC - Static variable in class io.servicetalk.http.api.HttpHeaderValues
-
"public"
- publishAndSubscribeOn(Executor) - Method in class io.servicetalk.concurrent.api.Completable
-
- publishAndSubscribeOn(Executor) - Method in class io.servicetalk.concurrent.api.Publisher
-
- publishAndSubscribeOn(Executor) - Method in class io.servicetalk.concurrent.api.Single
-
- publishAndSubscribeOnOverride(Executor) - Method in class io.servicetalk.concurrent.api.Completable
-
- publishAndSubscribeOnOverride(Executor) - Method in class io.servicetalk.concurrent.api.Publisher
-
- publishAndSubscribeOnOverride(Executor) - Method in class io.servicetalk.concurrent.api.Single
-
- Publisher<T> - Class in io.servicetalk.concurrent.api
-
An asynchronous computation that produces 0, 1 or more elements and may or may not terminate successfully or with
an error.
- Publisher() - Constructor for class io.servicetalk.concurrent.api.Publisher
-
New instance.
- publisherConsumingResource() - Method in class io.servicetalk.http.router.jersey.IllBehavedRequestFilterTest
-
- publisherInputStreamQueueCapacity(int) - Method in class io.servicetalk.http.router.jersey.HttpJerseyRouterBuilder
-
Set the hint for the capacity of the intermediary queue that stores items when adapting
Publisher
s
into
InputStream
s.
- PublisherOperator<T,R> - Interface in io.servicetalk.concurrent.api
-
- PublisherProcessorSignalsHolder<T> - Interface in io.servicetalk.concurrent.api
-
- publisherResources() - Method in class io.servicetalk.http.router.jersey.AbstractFilterInterceptorTest
-
- PublisherSource<T> - Interface in io.servicetalk.concurrent
-
An asynchronous computation that emits zero or more items to its
PublisherSource.Subscriber
and may or may not terminate
successfully or with an error.
- PublisherSource(Publisher<T>) - Constructor for class io.servicetalk.http.router.jersey.internal.SourceWrappers.PublisherSource
-
- PublisherSource.Processor<T,R> - Interface in io.servicetalk.concurrent
-
- PublisherSource.Subscriber<T> - Interface in io.servicetalk.concurrent
-
A subscriber of result(s) produced by a PublisherSource
.
- PublisherSource.Subscription - Interface in io.servicetalk.concurrent
-
- PublisherToSingleOperator<T,R> - Interface in io.servicetalk.concurrent.api
-
- publishOn(Executor) - Method in class io.servicetalk.concurrent.api.Completable
-
- publishOn(Executor) - Method in class io.servicetalk.concurrent.api.Publisher
-
- publishOn(Executor) - Method in class io.servicetalk.concurrent.api.Single
-
- publishOnOverride(Executor) - Method in class io.servicetalk.concurrent.api.Completable
-
- publishOnOverride(Executor) - Method in class io.servicetalk.concurrent.api.Publisher
-
- publishOnOverride(Executor) - Method in class io.servicetalk.concurrent.api.Single
-
- put(AsyncContextMap.Key<T>, T) - Static method in class io.servicetalk.concurrent.api.AsyncContext
-
Convenience method for adding a value to the current context.
- put(AsyncContextMap.Key<T>, T) - Method in interface io.servicetalk.concurrent.api.AsyncContextMap
-
- put(String) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequestFactory
-
- put(String) - Method in interface io.servicetalk.http.api.HttpRequestFactory
-
- PUT - Static variable in class io.servicetalk.http.api.HttpRequestMethod
-
- put(String) - Method in interface io.servicetalk.http.api.StreamingHttpRequestFactory
-
- put(String, CharSequence, CharSequence) - Method in class io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest
-
- put(String, String) - Method in class io.servicetalk.log4j2.mdc.utils.ServiceTalkThreadContextMap
-
- putAll(Map<AsyncContextMap.Key<?>, Object>) - Static method in class io.servicetalk.concurrent.api.AsyncContext
-
Convenience method for to put all the key/value pairs into the current context.
- putAll(Map<AsyncContextMap.Key<?>, Object>) - Method in interface io.servicetalk.concurrent.api.AsyncContextMap
-
- putAll(Map<String, String>) - Method in class io.servicetalk.log4j2.mdc.utils.ServiceTalkThreadContextMap
-
- putJsonResponse() - Method in class io.servicetalk.http.router.jersey.AbstractResourceTest
-
- putJsonResponse() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- putJsonResponse(Map<String, Object>) - Method in class io.servicetalk.http.router.jersey.resources.AsynchronousResources
-
- putJsonResponse(Map<String, Object>) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- randomCharSequenceOfByteLength(int) - Static method in class io.servicetalk.transport.netty.internal.RandomDataUtils
-
Generates a new random CharSequence
whose UTF-8 encoding is of the specified size.
- RandomDataUtils - Class in io.servicetalk.transport.netty.internal
-
- range(int, int) - Static method in class io.servicetalk.concurrent.api.Publisher
-
Create a new
Publisher
that when subscribed will emit all
Integer
s within the range of
[
begin
,
end
).
- range(int, int, int) - Static method in class io.servicetalk.concurrent.api.Publisher
-
Create a new
Publisher
that when subscribed will emit all
Integer
s within the range of
[
begin
,
end
) with an increment of
stride
between each signal.
- RANGE - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"range"
- RANGE_NOT_SATISFIABLE - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
416 Range Not Satisfiable
- rangeNotSatisfiable() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- rangeNotSatisfiable() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- rangeNotSatisfiable() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- rawPath(String) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- rawPath(String) - Method in interface io.servicetalk.http.api.HttpRequest
-
- rawPath() - Method in interface io.servicetalk.http.api.HttpRequestMetaData
-
- rawPath(String) - Method in interface io.servicetalk.http.api.HttpRequestMetaData
-
Sets the path to path
, without any encoding performed.
- rawPath(String) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- rawQuery(String) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- rawQuery(String) - Method in interface io.servicetalk.http.api.HttpRequest
-
- rawQuery() - Method in interface io.servicetalk.http.api.HttpRequestMetaData
-
- rawQuery(String) - Method in interface io.servicetalk.http.api.HttpRequestMetaData
-
- rawQuery(String) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- ReactiveStreamsAdapters - Class in io.servicetalk.concurrent.reactivestreams
-
A set of adapter methods for converting to and from
Reactive Streams APIs and ServiceTalk APIs.
- read(byte[], int, int) - Method in class io.servicetalk.concurrent.internal.AbstractCloseableIteratorAsInputStream
-
- read() - Method in class io.servicetalk.concurrent.internal.AbstractCloseableIteratorAsInputStream
-
- read() - Method in class io.servicetalk.http.router.jersey.AbstractFilterInterceptorTest.UpperCaseInputStream
-
- read(byte[], int, int) - Method in class io.servicetalk.http.router.jersey.AbstractFilterInterceptorTest.UpperCaseInputStream
-
- read() - Method in class io.servicetalk.http.router.jersey.internal.BufferPublisherInputStream
-
- read(byte[], int, int) - Method in class io.servicetalk.http.router.jersey.internal.BufferPublisherInputStream
-
- read() - Method in class io.servicetalk.transport.netty.internal.DefaultNettyConnection
-
- read() - Method in interface io.servicetalk.transport.netty.internal.NettyConnection
-
Returns
Publisher
that emits all items as read from this connection.
- readableBytes() - Method in interface io.servicetalk.buffer.api.Buffer
-
Returns the number of readable bytes which is equal to
(this.writerIndex - this.readerIndex)
.
- readableBytes() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readBoolean() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets a boolean at the current readerIndex
and increases
the readerIndex
by 1
in this buffer.
- readBoolean() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readByte() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets a byte at the current readerIndex
and increases
the readerIndex
by 1
in this buffer.
- readByte() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readBytes(int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers this buffer's data to a newly created buffer starting at
the current readerIndex
and increases the readerIndex
by the number of the transferred bytes (= length
).
- readBytes(Buffer) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers this buffer's data to the specified destination starting at
the current readerIndex
until the destination becomes
non-writable, and increases the readerIndex
by the number of the
transferred bytes.
- readBytes(Buffer, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers this buffer's data to the specified destination starting at
the current readerIndex
and increases the readerIndex
by the number of the transferred bytes (= length
).
- readBytes(Buffer, int, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers this buffer's data to the specified destination starting at
the current readerIndex
and increases the readerIndex
by the number of the transferred bytes (= length
).
- readBytes(byte[]) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers this buffer's data to the specified destination starting at
the current readerIndex
and increases the readerIndex
by the number of the transferred bytes (= dst.length
).
- readBytes(byte[], int, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers this buffer's data to the specified destination starting at
the current readerIndex
and increases the readerIndex
by the number of the transferred bytes (= length
).
- readBytes(ByteBuffer) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers this buffer's data to the specified destination starting at
the current readerIndex
until the destination's position
reaches its limit, and increases the readerIndex
by the
number of the transferred bytes.
- readBytes(int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readBytes(Buffer) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readBytes(Buffer, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readBytes(Buffer, int, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readBytes(byte[]) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readBytes(byte[], int, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readBytes(ByteBuffer) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readChar() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets a 2-byte UTF-16 character at the current readerIndex
and increases the readerIndex
by 2
in this buffer.
- readChar() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readDouble() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets a 64-bit floating point number at the current readerIndex
and increases the readerIndex
by 8
in this buffer.
- readDouble() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readerIndex() - Method in interface io.servicetalk.buffer.api.Buffer
-
Returns the readerIndex
of this buffer.
- readerIndex(int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the readerIndex
of this buffer.
- readerIndex(int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- readerIndex() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readerIndex(int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readFloat() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets a 32-bit floating point number at the current readerIndex
and increases the readerIndex
by 4
in this buffer.
- readFloat() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readInt() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets a 32-bit integer at the current readerIndex
and increases the readerIndex
by 4
in this buffer.
- readInt() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readIntLE() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets a 32-bit integer at the current readerIndex
in the Little Endian Byte Order and increases the readerIndex
by 4
in this buffer.
- readIntLE() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readLong() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets a 64-bit integer at the current readerIndex
and increases the readerIndex
by 8
in this buffer.
- readLong() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readLongLE() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets a 64-bit integer at the current readerIndex
in the Little Endian Byte Order and increases the readerIndex
by 8
in this buffer.
- readLongLE() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readMedium() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets a 24-bit medium integer at the current readerIndex
and increases the readerIndex
by 3
in this buffer.
- readMedium() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readMediumLE() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets a 24-bit medium integer at the current readerIndex
in the Little Endian Byte Order and increases the
readerIndex
by 3
in this buffer.
- readMediumLE() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- ReadOnlyBufferAllocators - Class in io.servicetalk.buffer.api
-
Utility class containing
BufferAllocator
s that create
Buffer
instances which cannot be modified and
are read only.
- ReadOnlyClientSecurityConfig - Class in io.servicetalk.transport.netty.internal
-
Read-only security config for clients.
- ReadOnlyClientSecurityConfig(String, int) - Constructor for class io.servicetalk.transport.netty.internal.ReadOnlyClientSecurityConfig
-
Creates new instance.
- ReadOnlyClientSecurityConfig(ReadOnlyClientSecurityConfig) - Constructor for class io.servicetalk.transport.netty.internal.ReadOnlyClientSecurityConfig
-
Copy constructor.
- ReadOnlyServerSecurityConfig - Class in io.servicetalk.transport.netty.internal
-
Read-only security config for servers.
- ReadOnlyServerSecurityConfig() - Constructor for class io.servicetalk.transport.netty.internal.ReadOnlyServerSecurityConfig
-
Creates new instance.
- ReadOnlyServerSecurityConfig(ReadOnlyServerSecurityConfig) - Constructor for class io.servicetalk.transport.netty.internal.ReadOnlyServerSecurityConfig
-
Copy constructor.
- ReadOnlyTcpClientConfig - Class in io.servicetalk.tcp.netty.internal
-
- ReadOnlyTcpServerConfig - Class in io.servicetalk.tcp.netty.internal
-
- readShort() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets a 16-bit short integer at the current readerIndex
and increases the readerIndex
by 2
in this buffer.
- readShort() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readShortLE() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets a 16-bit short integer at the current readerIndex
in the Little Endian Byte Order and increases the readerIndex
by 2
in this buffer.
- readShortLE() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readSlice(int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Returns a new slice of this buffer's sub-region starting at the current
readerIndex
and increases the readerIndex
by the size
of the new slice (= length
).
- readSlice(int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readUnsignedByte() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets an unsigned byte at the current readerIndex
and increases
the readerIndex
by 1
in this buffer.
- readUnsignedByte() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readUnsignedInt() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets an unsigned 32-bit integer at the current readerIndex
and increases the readerIndex
by 4
in this buffer.
- readUnsignedInt() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readUnsignedIntLE() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets an unsigned 32-bit integer at the current readerIndex
in the Little Endian Byte Order and increases the readerIndex
by 4
in this buffer.
- readUnsignedIntLE() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readUnsignedMedium() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets an unsigned 24-bit medium integer at the current readerIndex
and increases the readerIndex
by 3
in this buffer.
- readUnsignedMedium() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readUnsignedMediumLE() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets an unsigned 24-bit medium integer at the current readerIndex
in the Little Endian Byte Order and increases the readerIndex
by 3
in this buffer.
- readUnsignedMediumLE() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readUnsignedShort() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets an unsigned 16-bit short integer at the current readerIndex
and increases the readerIndex
by 2
in this buffer.
- readUnsignedShort() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- readUnsignedShortLE() - Method in interface io.servicetalk.buffer.api.Buffer
-
Gets an unsigned 16-bit short integer at the current readerIndex
in the Little Endian Byte Order and increases the readerIndex
by 2
in this buffer.
- readUnsignedShortLE() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- ready() - Method in class io.servicetalk.transport.netty.internal.DeferSslHandler
-
Indicates that we are ready to stop deferring, and add the deferred SslHandler
.
- reasonPhrase() - Method in class io.servicetalk.http.api.HttpResponseStatus
-
Get the
reason-phrase that provides a
textual description associated with the numeric status code.
- recoverWith(Function<Throwable, ? extends Publisher<? extends T>>) - Method in class io.servicetalk.concurrent.api.Publisher
-
Recover from any error emitted by this
Publisher
by using another
Publisher
provided by the
passed
nextFactory
.
- recoverWith(Function<Throwable, ? extends Single<? extends T>>) - Method in class io.servicetalk.concurrent.api.Single
-
Recover from any error emitted by this
Single
by using another
Single
provided by the
passed
nextFactory
.
- RedirectingHttpRequesterFilter - Class in io.servicetalk.http.utils
-
- RedirectingHttpRequesterFilter() - Constructor for class io.servicetalk.http.utils.RedirectingHttpRequesterFilter
-
Create a new instance, only performing relative redirects.
- RedirectingHttpRequesterFilter(int) - Constructor for class io.servicetalk.http.utils.RedirectingHttpRequesterFilter
-
Create a new instance, only performing relative redirects.
- RedirectingHttpRequesterFilter(boolean) - Constructor for class io.servicetalk.http.utils.RedirectingHttpRequesterFilter
-
Create a new instance, performing relative redirects only for
HttpConnection
.
- RedirectingHttpRequesterFilter(boolean, int) - Constructor for class io.servicetalk.http.utils.RedirectingHttpRequesterFilter
-
Create a new instance, performing relative redirects only for
HttpConnection
.
- RedirectingHttpRequesterFilter(boolean, boolean) - Constructor for class io.servicetalk.http.utils.RedirectingHttpRequesterFilter
-
Create a new instance.
- RedirectingHttpRequesterFilter(boolean, boolean, int) - Constructor for class io.servicetalk.http.utils.RedirectingHttpRequesterFilter
-
Create a new instance.
- references() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpan
-
Returns an immutable list of references.
- REFERER - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"referer"
- referredTo() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemoryReference
-
Returns the span being referred to.
- ReflectionUtils - Class in io.servicetalk.utils.internal
-
Provide utilities to assist reflective access.
- regionMatches(CharSequence, boolean, int, CharSequence, int, int) - Static method in class io.servicetalk.http.api.CharSequences
-
This methods make regionMatches operation correctly for any chars in strings.
- registerMessageType(Class<T>, Parser<T>) - Method in class io.servicetalk.grpc.protobuf.ProtoBufSerializationProviderBuilder
-
Register the passed messageType
with the provided Parser
.
- registerRoutes(Service) - Method in class io.servicetalk.grpc.api.GrpcRoutes
-
Register all routes contained in the passed Service
.
- RejectedSubscribeError - Interface in io.servicetalk.concurrent.internal
-
Used in scenarios where a subscribe to an asynchronous source is attempted, but no "real" subscription is
established.
- RejectedSubscribeException - Exception in io.servicetalk.concurrent.internal
-
Used in scenarios where a subscribe to an asynchronous source is attempted, but no "real" subscription is
established.
- RejectedSubscribeException(String) - Constructor for exception io.servicetalk.concurrent.internal.RejectedSubscribeException
-
Create a new instance.
- RejectedSubscribeException(Throwable) - Constructor for exception io.servicetalk.concurrent.internal.RejectedSubscribeException
-
Create a new instance.
- release() - Method in interface io.servicetalk.http.api.ReservedBlockingHttpConnection
-
- release() - Method in interface io.servicetalk.http.api.ReservedBlockingStreamingHttpConnection
-
- releaseAsync() - Method in interface io.servicetalk.client.api.internal.ReservableRequestConcurrencyController
-
- releaseAsync() - Method in interface io.servicetalk.http.api.FilterableReservedStreamingHttpConnection
-
- releaseAsync() - Method in interface io.servicetalk.http.api.ReservedHttpConnection
-
- releaseAsync() - Method in class io.servicetalk.http.api.ReservedStreamingHttpConnectionFilter
-
- releaseLock(AtomicIntegerFieldUpdater<T>, T) - Static method in class io.servicetalk.concurrent.internal.ConcurrentUtils
-
- releaseReentrantLock(AtomicLongFieldUpdater<T>, long, T) - Static method in class io.servicetalk.concurrent.internal.ConcurrentUtils
-
- remoteAddress() - Method in class io.servicetalk.http.api.AbstractHttpRequesterFilterTest
-
- remoteAddress() - Method in class io.servicetalk.http.api.AbstractHttpServiceFilterTest
-
- remoteAddress() - Method in class io.servicetalk.http.api.DelegatingHttpServiceContext
-
- remoteAddress() - Method in class io.servicetalk.http.api.TestHttpServiceContext
-
- remoteAddress() - Method in interface io.servicetalk.transport.api.ConnectionContext
-
The SocketAddress
to which the associated connection is connected.
- remoteAddress() - Method in class io.servicetalk.transport.api.DelegatingConnectionContext
-
- remoteAddress() - Method in class io.servicetalk.transport.netty.internal.DefaultNettyConnection
-
- remove(PartitionAttributes) - Method in class io.servicetalk.client.api.internal.partition.PowerSetPartitionMap
-
- remove(PartitionAttributes) - Method in interface io.servicetalk.client.api.partition.PartitionMap
-
- remove(AsyncContextMap.Key<?>) - Static method in class io.servicetalk.concurrent.api.AsyncContext
-
Convenience method to remove a key/value pair from the current context.
- remove(AsyncContextMap.Key<T>) - Method in interface io.servicetalk.concurrent.api.AsyncContextMap
-
Remove a key/value pair from this
AsyncContextMap
, and get the previous value (if one exists).
- remove(CharSequence) - Method in class io.servicetalk.http.api.EmptyHttpHeaders
-
- remove(CharSequence, CharSequence) - Method in class io.servicetalk.http.api.EmptyHttpHeaders
-
- remove(CharSequence) - Method in interface io.servicetalk.http.api.HttpHeaders
-
Removes all headers with the specified name
.
- remove(CharSequence, CharSequence) - Method in interface io.servicetalk.http.api.HttpHeaders
-
Removes specific value(s) from the specified header name
.
- remove() - Static method in class io.servicetalk.log4j2.mdc.utils.LoggerStringWriter
-
Remove the underlying in-memory log appender.
- remove(String) - Method in class io.servicetalk.log4j2.mdc.utils.ServiceTalkThreadContextMap
-
- removeAll(Iterable<AsyncContextMap.Key<?>>) - Static method in class io.servicetalk.concurrent.api.AsyncContext
-
Convenience method to remove all the key/value pairs from the current context.
- removeAll(Iterable<AsyncContextMap.Key<?>>) - Method in interface io.servicetalk.concurrent.api.AsyncContextMap
-
Remove all key/value pairs from this
AsyncContextMap
associated with the keys from the
Iterable
.
- removeAll(Iterable<String>) - Method in class io.servicetalk.log4j2.mdc.utils.ServiceTalkThreadContextMap
-
- removeCookiePairs(CharSequence, CharSequence) - Static method in class io.servicetalk.http.api.HeaderUtils
-
- removeCookies(CharSequence) - Method in class io.servicetalk.http.api.EmptyHttpHeaders
-
- removeCookies(CharSequence) - Method in interface io.servicetalk.http.api.HttpHeaders
-
Removes all
cookie identified by
name
.
- removeIgnoreCase(CharSequence, CharSequence) - Method in class io.servicetalk.http.api.EmptyHttpHeaders
-
- removeIgnoreCase(CharSequence, CharSequence) - Method in interface io.servicetalk.http.api.HttpHeaders
-
Removes specific value(s) from the specified header name
.
- removeQueryParameters(String) - Method in interface io.servicetalk.http.api.HttpRequestMetaData
-
Removes all query parameters with the specified key
.
- removeQueryParameters(String, String) - Method in interface io.servicetalk.http.api.HttpRequestMetaData
-
Removes all query parameters with the specified key
and value
.
- removeSetCookies(CharSequence) - Method in class io.servicetalk.http.api.EmptyHttpHeaders
-
- removeSetCookies(CharSequence, CharSequence, CharSequence) - Method in class io.servicetalk.http.api.EmptyHttpHeaders
-
- removeSetCookies(CharSequence) - Method in interface io.servicetalk.http.api.HttpHeaders
-
- removeSetCookies(CharSequence, CharSequence, CharSequence) - Method in interface io.servicetalk.http.api.HttpHeaders
-
- repeat(IntPredicate) - Method in class io.servicetalk.concurrent.api.Completable
-
Re-subscribes to this
Completable
when it completes and the passed
IntPredicate
returns
true
.
- repeat(IntPredicate) - Method in class io.servicetalk.concurrent.api.Publisher
-
Re-subscribes to this
Publisher
when it completes and the passed
IntPredicate
returns
true
.
- repeat(IntPredicate) - Method in class io.servicetalk.concurrent.api.Single
-
Re-subscribes to this
Single
when it completes and the passed
IntPredicate
returns
true
.
- RepeatStrategies - Class in io.servicetalk.concurrent.api
-
- RepeatStrategies.TerminateRepeatException - Exception in io.servicetalk.concurrent.api
-
An Exception
instance used to indicate termination of repeats.
- repeatWhen(IntFunction<? extends Completable>) - Method in class io.servicetalk.concurrent.api.Completable
-
Re-subscribes to this
Completable
when it completes and the
Completable
returned by the supplied
IntFunction
completes successfully.
- repeatWhen(IntFunction<? extends Completable>) - Method in class io.servicetalk.concurrent.api.Publisher
-
Re-subscribes to this
Publisher
when it completes and the
Completable
returned by the supplied
IntFunction
completes successfully.
- repeatWhen(IntFunction<? extends Completable>) - Method in class io.servicetalk.concurrent.api.Single
-
Re-subscribes to this
Single
when it completes and the
Completable
returned by the supplied
IntFunction
completes successfully.
- repeatWithConstantBackoff(int, Duration, Executor) - Static method in class io.servicetalk.concurrent.api.RepeatStrategies
-
Creates a new repeat function that adds the passed constant Duration
as delay between repeats.
- repeatWithExponentialBackoff(int, Duration, Executor) - Static method in class io.servicetalk.concurrent.api.RepeatStrategies
-
Creates a new repeat function that adds a delay between repeats.
- repeatWithExponentialBackoffAndJitter(int, Duration, Executor) - Static method in class io.servicetalk.concurrent.api.RepeatStrategies
-
Creates a new repeat function that adds a delay between repeats.
- replace(Buffer) - Method in interface io.servicetalk.buffer.api.BufferHolder
-
Returns a new
BufferHolder
which contains the specified
content
.
- replace(HttpHeaders) - Method in class io.servicetalk.http.api.EmptyHttpHeaders
-
- replace(HttpHeaders) - Method in interface io.servicetalk.http.api.HttpHeaders
-
Removes all header names contained in headers
from this object, and then adds all headers contained in
headers
.
- report(Span) - Method in class io.servicetalk.opentracing.zipkin.publisher.reporter.HttpReporter
-
- report(Span) - Method in class io.servicetalk.opentracing.zipkin.publisher.reporter.LoggingReporter
-
Logs a Span
to the configured logger.
- report(Span) - Method in class io.servicetalk.opentracing.zipkin.publisher.reporter.UdpReporter
-
- request(long) - Method in class io.servicetalk.concurrent.api.DeferredEmptySubscription
-
- request(long) - Method in class io.servicetalk.concurrent.api.TestPublisherSubscriber
-
- request(long) - Method in class io.servicetalk.concurrent.api.TestSubscription
-
- request(long) - Method in class io.servicetalk.concurrent.internal.ConcurrentSubscription
-
- request(long) - Method in class io.servicetalk.concurrent.internal.DelayedSubscription
-
- request(long) - Method in class io.servicetalk.concurrent.internal.EmptySubscription
-
- request(long) - Method in class io.servicetalk.concurrent.internal.ScalarValueSubscription
-
- request(long) - Method in interface io.servicetalk.concurrent.PublisherSource.Subscription
-
- request(GrpcClientMetadata, Req) - Method in interface io.servicetalk.grpc.api.GrpcClientCallFactory.BlockingClientCall
-
Sends the passed Req
.
- request(GrpcClientMetadata, Iterable<Req>) - Method in interface io.servicetalk.grpc.api.GrpcClientCallFactory.BlockingRequestStreamingClientCall
-
- request(GrpcClientMetadata, Req) - Method in interface io.servicetalk.grpc.api.GrpcClientCallFactory.BlockingResponseStreamingClientCall
-
Sends the passed Req
.
- request(GrpcClientMetadata, Iterable<Req>) - Method in interface io.servicetalk.grpc.api.GrpcClientCallFactory.BlockingStreamingClientCall
-
- request(GrpcClientMetadata, Req) - Method in interface io.servicetalk.grpc.api.GrpcClientCallFactory.ClientCall
-
Sends the passed Req
.
- request(GrpcClientMetadata, Publisher<Req>) - Method in interface io.servicetalk.grpc.api.GrpcClientCallFactory.RequestStreamingClientCall
-
- request(GrpcClientMetadata, Req) - Method in interface io.servicetalk.grpc.api.GrpcClientCallFactory.ResponseStreamingClientCall
-
Sends the passed Req
.
- request(GrpcClientMetadata, Publisher<Req>) - Method in interface io.servicetalk.grpc.api.GrpcClientCallFactory.StreamingClientCall
-
- request(StreamingHttpResponseFactory, StreamingHttpRequest) - Method in interface io.servicetalk.http.api.AbstractHttpRequesterFilterTest.RequestHandler
-
Handle requests from the filter under test.
- request(StreamingHttpResponseFactory, ConnectionContext, StreamingHttpRequest) - Method in interface io.servicetalk.http.api.AbstractHttpRequesterFilterTest.RequestWithContextHandler
-
- request(HttpRequest) - Method in interface io.servicetalk.http.api.BlockingHttpClient
-
Send a request
.
- request(HttpRequest) - Method in interface io.servicetalk.http.api.BlockingHttpConnection
-
Send a request
.
- request(HttpExecutionStrategy, HttpRequest) - Method in interface io.servicetalk.http.api.BlockingHttpRequester
-
Send a
request
using the passed
strategy
.
- request(BlockingStreamingHttpRequest) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpClient
-
Send a request
.
- request(BlockingStreamingHttpRequest) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpConnection
-
Send a request
.
- request(HttpExecutionStrategy, BlockingStreamingHttpRequest) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequester
-
Send a
request
using the passed
strategy
.
- request(HttpRequest) - Method in interface io.servicetalk.http.api.HttpClient
-
Send a request
.
- request(HttpRequest) - Method in interface io.servicetalk.http.api.HttpConnection
-
Send a request
.
- request(HttpExecutionStrategy, HttpRequest) - Method in interface io.servicetalk.http.api.HttpRequester
-
Send a
request
using the specified
strategy
.
- request(HttpExecutionStrategy, StreamingHttpRequest) - Method in class io.servicetalk.http.api.ReservedStreamingHttpConnectionFilter
-
- request(StreamingHttpRequester, HttpExecutionStrategy, StreamingHttpRequest) - Method in class io.servicetalk.http.api.ReservedStreamingHttpConnectionFilter
-
- request(StreamingHttpRequest) - Method in interface io.servicetalk.http.api.StreamingHttpClient
-
Send a request
.
- request(HttpExecutionStrategy, StreamingHttpRequest) - Method in class io.servicetalk.http.api.StreamingHttpClientFilter
-
- request(StreamingHttpRequester, HttpExecutionStrategy, StreamingHttpRequest) - Method in class io.servicetalk.http.api.StreamingHttpClientFilter
-
- request(StreamingHttpRequest) - Method in interface io.servicetalk.http.api.StreamingHttpConnection
-
Send a request
.
- request(HttpExecutionStrategy, StreamingHttpRequest) - Method in class io.servicetalk.http.api.StreamingHttpConnectionFilter
-
- request(HttpExecutionStrategy, StreamingHttpRequest) - Method in interface io.servicetalk.http.api.StreamingHttpRequester
-
Send a
request
using the specified
strategy
.
- REQUEST_HEADER_FIELDS_TOO_LARGE - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
431 Request Header Fields Too Large
- REQUEST_TIMEOUT - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
408 Request Timeout
- RequestConcurrencyController - Interface in io.servicetalk.client.api.internal
-
An interface which allows controlling reserving connections which maybe used concurrently.
- RequestConcurrencyController.Result - Enum in io.servicetalk.client.api.internal
-
- RequestConcurrencyControllers - Class in io.servicetalk.client.api.internal
-
- requested() - Method in class io.servicetalk.concurrent.api.TestSubscription
-
- requestedEquals(long) - Method in class io.servicetalk.concurrent.api.TestSubscription
-
- requesterTypes() - Static method in class io.servicetalk.http.api.AbstractHttpRequesterFilterTest
-
- requestFinished() - Method in interface io.servicetalk.client.api.internal.RequestConcurrencyController
-
- requestHeaderFieldsTooLarge() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- requestHeaderFieldsTooLarge() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- requestHeaderFieldsTooLarge() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- RequestProperties - Class in io.servicetalk.http.router.jersey.internal
-
Helper methods used internally for accessing ServiceTalk-specific request properties.
- requestStreamingRouteFor(String) - Method in interface io.servicetalk.grpc.api.GrpcRoutes.AllGrpcRoutes
-
- requestTarget(String) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- requestTarget(String) - Method in interface io.servicetalk.http.api.HttpRequest
-
- requestTarget() - Method in interface io.servicetalk.http.api.HttpRequestMetaData
-
- requestTarget(String) - Method in interface io.servicetalk.http.api.HttpRequestMetaData
-
- requestTarget(String) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- requestTimeout() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- requestTimeout() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- requestTimeout() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- ReservableRequestConcurrencyController - Interface in io.servicetalk.client.api.internal
-
- ReservableRequestConcurrencyControllers - Class in io.servicetalk.client.api.internal
-
- reserveConnection(HttpRequestMetaData) - Method in interface io.servicetalk.http.api.BlockingHttpClient
-
- reserveConnection(HttpExecutionStrategy, HttpRequestMetaData) - Method in interface io.servicetalk.http.api.BlockingHttpClient
-
- reserveConnection(HttpRequestMetaData) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpClient
-
- reserveConnection(HttpExecutionStrategy, HttpRequestMetaData) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpClient
-
- reserveConnection(HttpExecutionStrategy, HttpRequestMetaData) - Method in interface io.servicetalk.http.api.FilterableStreamingHttpClient
-
- reserveConnection(HttpRequestMetaData) - Method in interface io.servicetalk.http.api.HttpClient
-
- reserveConnection(HttpExecutionStrategy, HttpRequestMetaData) - Method in interface io.servicetalk.http.api.HttpClient
-
- reserveConnection(HttpRequestMetaData) - Method in interface io.servicetalk.http.api.StreamingHttpClient
-
- reserveConnection(HttpExecutionStrategy, HttpRequestMetaData) - Method in interface io.servicetalk.http.api.StreamingHttpClient
-
- reserveConnection(HttpExecutionStrategy, HttpRequestMetaData) - Method in class io.servicetalk.http.api.StreamingHttpClientFilter
-
- ReservedBlockingHttpConnection - Interface in io.servicetalk.http.api
-
- ReservedBlockingStreamingHttpConnection - Interface in io.servicetalk.http.api
-
- ReservedHttpConnection - Interface in io.servicetalk.http.api
-
- ReservedStreamingHttpConnection - Interface in io.servicetalk.http.api
-
- ReservedStreamingHttpConnectionFilter - Class in io.servicetalk.http.api
-
- ReservedStreamingHttpConnectionFilter(FilterableReservedStreamingHttpConnection) - Constructor for class io.servicetalk.http.api.ReservedStreamingHttpConnectionFilter
-
Create a new instance.
- reserveMemory(long, int) - Static method in class io.servicetalk.utils.internal.PlatformDependent
-
Reserves direct memory for the specified size and capacity.
- reset() - Method in class io.servicetalk.concurrent.api.LegacyMockedCompletableListenerRule
-
Deprecated.
- reset() - Static method in class io.servicetalk.log4j2.mdc.utils.LoggerStringWriter
-
- RESET_CONTENT - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
205 Reset Content
- resetContent() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- resetContent() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- resetContent() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- resetSubscriberMock() - Method in class io.servicetalk.concurrent.api.LegacyMockedSingleListenerRule
-
Deprecated.
- resolutionCompleted(DnsServiceDiscovererObserver.ResolutionResult) - Method in interface io.servicetalk.dns.discovery.netty.DnsServiceDiscovererObserver.DnsResolutionObserver
-
Notifies that the current DNS resolution completed successfully.
- resolutionFailed(Throwable) - Method in interface io.servicetalk.dns.discovery.netty.DnsServiceDiscovererObserver.DnsResolutionObserver
-
Notifies that the current DNS resolution failed.
- resolvedRecords() - Method in interface io.servicetalk.dns.discovery.netty.DnsServiceDiscovererObserver.ResolutionResult
-
Number of resolved DNS records.
- ResourceDefaultStrategy() - Constructor for class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.ResourceDefaultStrategy
-
- ResourceInvalidExecStrategy() - Constructor for class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.ResourceInvalidExecStrategy
-
- ResourceRouteExecIdStrategy() - Constructor for class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.ResourceRouteExecIdStrategy
-
- ResourceRouteNoOffloadsStrategy() - Constructor for class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.ResourceRouteNoOffloadsStrategy
-
- ResourceUnsupportedAsync() - Constructor for class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.ResourceUnsupportedAsync
-
- responseFactory() - Method in class io.servicetalk.http.api.HttpServiceContext
-
- responseFactory() - Method in class io.servicetalk.http.api.TestHttpServiceContext
-
- responseStreamingRouteFor(String) - Method in interface io.servicetalk.grpc.api.GrpcRoutes.AllGrpcRoutes
-
- result() - Method in class io.servicetalk.concurrent.api.TestSingleSubscriber
-
- resumeSuspended() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- resumeSuspendedWithJson() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- retrieveMethod(Class<?>, String, Class<?>...) - Static method in class io.servicetalk.utils.internal.ReflectionUtils
-
Retrieves the specific Method
from the Class
without checked exception.
- retry(BiIntPredicate<Throwable>) - Method in class io.servicetalk.concurrent.api.Completable
-
- retry(BiIntPredicate<Throwable>) - Method in class io.servicetalk.concurrent.api.Publisher
-
- retry(BiIntPredicate<Throwable>) - Method in class io.servicetalk.concurrent.api.Single
-
- RETRY_AFTER - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"retry-after"
- RetryableConnectException - Exception in io.servicetalk.client.api
-
Throws when a connect operations failed.
- RetryableConnectException(String) - Constructor for exception io.servicetalk.client.api.RetryableConnectException
-
New instance.
- RetryableConnectException(ConnectException) - Constructor for exception io.servicetalk.client.api.RetryableConnectException
-
Create a new instance.
- RetryableException - Interface in io.servicetalk.transport.api
-
A marker-interface for exceptions which are safely retryable and occur only before ServiceTalk starts writing a
request to the network.
- retryFor(BiPredicate<Meta, Throwable>) - Method in class io.servicetalk.client.api.AbstractRetryingFilterBuilder
-
Overrides the default criterion for determining which requests or errors should be retried.
- retryForIdempotentRequestsPredicate() - Method in class io.servicetalk.http.utils.RetryingHttpRequesterFilter.Builder
-
- RetryingHttpRequesterFilter - Class in io.servicetalk.http.utils
-
A filter to enable retries for HTTP requests.
- RetryingHttpRequesterFilter.Builder - Class in io.servicetalk.http.utils
-
- retryServiceDiscoveryErrors(BiIntFunction<Throwable, ? extends Completable>) - Method in class io.servicetalk.http.api.MultiAddressHttpClientBuilder
-
- retryServiceDiscoveryErrors(BiIntFunction<Throwable, ? extends Completable>) - Method in class io.servicetalk.http.api.PartitionedHttpClientBuilder
-
- retryServiceDiscoveryErrors(BiIntFunction<Throwable, ? extends Completable>) - Method in class io.servicetalk.http.api.SingleAddressHttpClientBuilder
-
- RetryStrategies - Class in io.servicetalk.concurrent.api
-
- retryWhen(BiIntFunction<Throwable, ? extends Completable>) - Method in class io.servicetalk.concurrent.api.Completable
-
- retryWhen(BiIntFunction<Throwable, ? extends Completable>) - Method in class io.servicetalk.concurrent.api.Publisher
-
- retryWhen(BiIntFunction<Throwable, ? extends Completable>) - Method in class io.servicetalk.concurrent.api.Single
-
- retryWithConstantBackoff(int, Predicate<Throwable>, Duration, Executor) - Static method in class io.servicetalk.concurrent.api.RetryStrategies
-
Creates a new retry function that adds the passed constant Duration
as a delay between retries.
- retryWithConstantBackoffAndJitter(int, Predicate<Throwable>, Duration, Executor) - Static method in class io.servicetalk.concurrent.api.RetryStrategies
-
Creates a new retry function that adds the passed constant Duration
as a delay between retries.
- retryWithExponentialBackoff(int, Predicate<Throwable>, Duration, Executor) - Static method in class io.servicetalk.concurrent.api.RetryStrategies
-
Creates a new retry function that adds a delay between retries.
- retryWithExponentialBackoffAndJitter(int, Predicate<Throwable>, Duration, Executor) - Static method in class io.servicetalk.concurrent.api.RetryStrategies
-
Creates a new retry function that adds a delay between retries.
- RoundRobinLoadBalancer<ResolvedAddress,C extends LoadBalancedConnection> - Class in io.servicetalk.loadbalancer
-
A
LoadBalancer
that uses a round robin strategy for selecting addresses.
- RoundRobinLoadBalancer(Publisher<? extends ServiceDiscovererEvent<ResolvedAddress>>, ConnectionFactory<ResolvedAddress, ? extends C>) - Constructor for class io.servicetalk.loadbalancer.RoundRobinLoadBalancer
-
Creates a new instance.
- RoundRobinLoadBalancer.RoundRobinLoadBalancerFactory<ResolvedAddress,C extends LoadBalancedConnection> - Class in io.servicetalk.loadbalancer
-
- RoundRobinLoadBalancerFactory() - Constructor for class io.servicetalk.loadbalancer.RoundRobinLoadBalancer.RoundRobinLoadBalancerFactory
-
- ROUTE_EXEC - Static variable in class io.servicetalk.http.router.jersey.ExecutionStrategyTest
-
- RouteContinuation - Interface in io.servicetalk.http.router.predicate.dsl
-
Methods for continuing a route.
- RouteExecutionStrategy - Annotation Type in io.servicetalk.router.api
-
Indicates that a resource class or method needs a specific execution strategy.
- routeExecutionStrategyFactory(RouteExecutionStrategyFactory<HttpExecutionStrategy>) - Method in class io.servicetalk.http.router.jersey.HttpJerseyRouterBuilder
-
- RouteExecutionStrategyFactory<ES> - Interface in io.servicetalk.router.api
-
- RouteExecutionStrategyUtils - Class in io.servicetalk.router.utils.internal
-
- routeFor(String) - Method in interface io.servicetalk.grpc.api.GrpcRoutes.AllGrpcRoutes
-
- ROUTER_EXEC - Static variable in class io.servicetalk.http.router.jersey.ExecutionStrategyTest
-
- RouteStarter - Interface in io.servicetalk.http.router.predicate.dsl
-
Methods for starting a route.
- RS_THREAD_NAME - Static variable in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources
-
- rsCancelDelayedDelayedStageResponse() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- rsCancelDelayedText() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- rsCancelSuspended() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- rule - Variable in class io.servicetalk.http.api.AbstractHttpRequesterFilterTest
-
- rule - Variable in class io.servicetalk.http.api.AbstractHttpServiceFilterTest
-
- rule - Variable in class io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest
-
- rule - Variable in class io.servicetalk.http.router.jersey.CancellationTest
-
- RunnableCompletable - Class in io.servicetalk.concurrent.api
-
- runTwiceToEnsureEndpointCache(Runnable) - Static method in class io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest
-
Runs the provided test
lambda multiple times.
- S_MAXAGE - Static variable in class io.servicetalk.http.api.HttpHeaderValues
-
"s-maxage"
- SAFE_IDEMPOTENT - Static variable in class io.servicetalk.http.api.HttpRequestMethod.Properties
-
As defined in
Method Definitions, methods which
are safe and idempotent, but not cacheable.
- SAFE_IDEMPOTENT_CACHEABLE - Static variable in class io.servicetalk.http.api.HttpRequestMethod.Properties
-
- safeFindNextPositivePowerOfTwo(int) - Static method in class io.servicetalk.utils.internal.MathUtils
-
Fast method of finding the next power of 2 greater than or equal to the supplied value.
- safeOnComplete(PublisherSource.Subscriber<T>) - Static method in class io.servicetalk.concurrent.internal.SubscriberUtils
-
- safeOnComplete(CompletableSource.Subscriber) - Static method in class io.servicetalk.concurrent.internal.SubscriberUtils
-
Invokes CompletableSource.Subscriber#onComplete()
ignoring an occurred exception if any.
- safeOnError(CompletableSource.Subscriber, Throwable) - Static method in class io.servicetalk.concurrent.internal.SubscriberUtils
-
Invokes CompletableSource.Subscriber#onError(Throwable)
ignoring an occurred exception if any.
- safeOnError(SingleSource.Subscriber<T>, Throwable) - Static method in class io.servicetalk.concurrent.internal.SubscriberUtils
-
Invokes SingleSource.Subscriber#onError(Throwable)
ignoring an occurred exception if any.
- safeOnError(PublisherSource.Subscriber<T>, Throwable) - Static method in class io.servicetalk.concurrent.internal.SubscriberUtils
-
Invokes PublisherSource.Subscriber#onError(Throwable)
ignoring an occurred exception if any.
- safeOnSuccess(SingleSource.Subscriber<T>, T) - Static method in class io.servicetalk.concurrent.internal.SubscriberUtils
-
Invokes SingleSource.Subscriber#onSuccess(Object)
ignoring an occurred exception if any.
- sameSite() - Method in class io.servicetalk.http.api.DefaultHttpSetCookie
-
- sameSite() - Method in interface io.servicetalk.http.api.HttpSetCookie
-
- SAMPLED - Static variable in class io.servicetalk.opentracing.internal.ZipkinHeaderNames
-
- sampleRespectRequestOrEveryN(int) - Static method in class io.servicetalk.opentracing.inmemory.SamplingStrategies
-
Filter that samples as requested, but if there is no request will sample approximately sampleCountHint
times.
- sampleUnlessFalse() - Static method in class io.servicetalk.opentracing.inmemory.SamplingStrategies
-
Sample unless explicitly requested to not sample.
- sampleWhenRequestedOrEveryN(int) - Static method in class io.servicetalk.opentracing.inmemory.SamplingStrategies
-
Filter that samples when requested, or otherwise treats no request and false
as the same and will filter
approximately sampleCountHint
times.
- SamplingStrategies - Class in io.servicetalk.opentracing.inmemory
-
Utility methods for sampling strategies.
- ScalarValueSubscription<T> - Class in io.servicetalk.concurrent.internal
-
- ScalarValueSubscription(T, PublisherSource.Subscriber<? super T>) - Constructor for class io.servicetalk.concurrent.internal.ScalarValueSubscription
-
New instance.
- schedule(Runnable, long, TimeUnit) - Method in class io.servicetalk.concurrent.api.DelegatingExecutor
-
- schedule(Runnable, Duration) - Method in class io.servicetalk.concurrent.api.DelegatingExecutor
-
- schedule(Runnable, long, TimeUnit) - Method in class io.servicetalk.concurrent.api.internal.OffloaderAwareExecutor
-
- schedule(Runnable, long, TimeUnit) - Method in class io.servicetalk.concurrent.api.TestExecutor
-
- schedule(Runnable, long, TimeUnit) - Method in interface io.servicetalk.concurrent.Executor
-
Executes the passed task
after delay
amount of unit
s time has passed.
- schedule(Runnable, Duration) - Method in interface io.servicetalk.concurrent.Executor
-
Executes the passed task
after delay
amount time has passed.
- scheduledTasksExecuted() - Method in class io.servicetalk.concurrent.api.TestExecutor
-
Returns the number of scheduled (schedule
/timer
methods) tasks that have been executed.
- scheduledTasksPending() - Method in class io.servicetalk.concurrent.api.TestExecutor
-
Returns the number of scheduled (schedule
/timer
methods) tasks currently pending.
- scheme() - Method in interface io.servicetalk.http.api.HttpRequestMetaData
-
- SCOPE_MANAGER - Static variable in class io.servicetalk.opentracing.asynccontext.AsyncContextInMemoryScopeManager
-
- scopeManager() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemoryTracer
-
- scopeManager() - Method in class io.servicetalk.opentracing.inmemory.DefaultInMemoryTracer
-
- score() - Method in interface io.servicetalk.client.api.ScoreSupplier
-
Returns the current score of a resource.
- ScoreSupplier - Interface in io.servicetalk.client.api
-
Enables components to expose a score.
- SEC_WEBSOCKET_ACCEPT - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"sec-websocket-accept"
- SEC_WEBSOCKET_EXTENSIONS - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"sec-websocket-protocol"
- SEC_WEBSOCKET_KEY - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"sec-websocket-key"
- SEC_WEBSOCKET_KEY1 - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"sec-websocket-key1"
- SEC_WEBSOCKET_KEY2 - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"sec-websocket-key2"
- SEC_WEBSOCKET_LOCATION - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"sec-websocket-location"
- SEC_WEBSOCKET_ORIGIN - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"sec-websocket-origin"
- SEC_WEBSOCKET_PROTOCOL - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"sec-websocket-protocol"
- SEC_WEBSOCKET_VERSION - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"sec-websocket-version"
- secure() - Method in class io.servicetalk.grpc.api.GrpcClientBuilder
-
- secure() - Method in class io.servicetalk.grpc.api.GrpcServerBuilder
-
Initiate security configuration for this server.
- secure(String...) - Method in class io.servicetalk.grpc.api.GrpcServerBuilder
-
Initiate security configuration for this server for the passed sniHostnames
.
- secure() - Method in class io.servicetalk.http.api.HttpServerBuilder
-
Initiates security configuration for this server.
- secure(String...) - Method in class io.servicetalk.http.api.HttpServerBuilder
-
Initiates security configuration for this server for the passed sniHostnames
.
- secure(BiConsumer<HostAndPort, ClientSecurityConfigurator>) - Method in class io.servicetalk.http.api.MultiAddressHttpClientBuilder
-
Sets a function that is used for configuring SSL/TLS for https requests.
- secure() - Method in class io.servicetalk.http.api.PartitionedHttpClientBuilder
-
Initiates security configuration for this client.
- secure() - Method in class io.servicetalk.http.api.SingleAddressHttpClientBuilder
-
Initiates security configuration for this client.
- secure(ReadOnlyServerSecurityConfig, String...) - Method in class io.servicetalk.tcp.netty.internal.TcpServerConfig
-
Add security related config.
- security - Variable in class io.servicetalk.http.api.AbstractHttpRequesterFilterTest
-
- security - Variable in class io.servicetalk.http.api.AbstractHttpServiceFilterTest
-
- SecurityConfigurator - Interface in io.servicetalk.transport.api
-
An abstraction to configure SSL/TLS.
- SecurityConfigurator.SslProvider - Enum in io.servicetalk.transport.api
-
The provider to use for SSLEngine
.
- securityContext(SecurityContext) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- securityContextFunction(SCF) - Method in class io.servicetalk.http.security.auth.basic.jersey.BasicAuthSecurityContextFilters.AbstractBuilder
-
Specify a custom function the filter will use to use to create SecurityContext
instances.
- SecurityFilterTest - Class in io.servicetalk.http.router.jersey
-
- SecurityFilterTest(AbstractNonParameterizedJerseyStreamingHttpServiceTest.RouterApi) - Constructor for class io.servicetalk.http.router.jersey.SecurityFilterTest
-
- SecurityFilterTest.TestApplication - Class in io.servicetalk.http.router.jersey
-
- SecurityFilterTest.TestSecurityFilter - Class in io.servicetalk.http.router.jersey
-
- securityTypes() - Static method in class io.servicetalk.http.api.AbstractHttpServiceFilterTest
-
- SEE_OTHER - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
303 See Other (since HTTP/1.1)
- seeOther() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- seeOther() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- seeOther() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- selectConnection(Predicate<C>) - Method in interface io.servicetalk.client.api.LoadBalancer
-
Select the most appropriate connection for a request.
- selectConnection(Predicate<C>) - Method in class io.servicetalk.loadbalancer.RoundRobinLoadBalancer
-
- sendAndAssertNoResponse(StreamingHttpRequest, HttpResponseStatus) - Method in class io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest
-
- sendAndAssertResponse(StreamingHttpRequest, HttpResponseStatus, CharSequence, String) - Method in class io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest
-
- sendAndAssertResponse(StreamingHttpRequest, HttpResponseStatus, CharSequence, Matcher<String>, int) - Method in class io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest
-
- sendAndAssertResponse(StreamingHttpRequest, HttpResponseStatus, CharSequence, Matcher<String>, Function<String, Integer>) - Method in class io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest
-
- sendAndAssertResponse(StreamingHttpRequest, HttpResponseStatus, CharSequence, String, int, TimeUnit) - Method in class io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest
-
- sendAndAssertResponse(StreamingHttpRequest, HttpProtocolVersion, HttpResponseStatus, CharSequence, Matcher<String>, Function<String, Integer>) - Method in class io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest
-
- sendAndAssertStatusOnly(StreamingHttpRequest, HttpResponseStatus) - Method in class io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest
-
- sendMetaData() - Method in class io.servicetalk.http.api.BlockingStreamingHttpServerResponse
-
- sendMetaData(HttpSerializer<T>) - Method in class io.servicetalk.http.api.BlockingStreamingHttpServerResponse
-
- sendMetaDataOutputStream() - Method in class io.servicetalk.http.api.BlockingStreamingHttpServerResponse
-
Sends the
HttpResponseMetaData
to the client and returns an
OutputStream
to continue writing a
payload body.
- sendOnSubscribe() - Method in class io.servicetalk.concurrent.api.LegacyTestCompletable
-
Deprecated.
- SequentialCancellable - Class in io.servicetalk.concurrent.internal
-
- SequentialCancellable() - Constructor for class io.servicetalk.concurrent.internal.SequentialCancellable
-
- SequentialCancellable(Cancellable) - Constructor for class io.servicetalk.concurrent.internal.SequentialCancellable
-
Create a new instance with the current
Cancellable
set to
cancellable
.
- SequentialCompletableSubscriberFunction - Class in io.servicetalk.concurrent.api
-
- SequentialCompletableSubscriberFunction() - Constructor for class io.servicetalk.concurrent.api.SequentialCompletableSubscriberFunction
-
- SequentialPublisherSubscriberFunction<T> - Class in io.servicetalk.concurrent.api
-
- SequentialPublisherSubscriberFunction() - Constructor for class io.servicetalk.concurrent.api.SequentialPublisherSubscriberFunction
-
- SequentialSingleSubscriberFunction<T> - Class in io.servicetalk.concurrent.api
-
- SequentialSingleSubscriberFunction() - Constructor for class io.servicetalk.concurrent.api.SequentialSingleSubscriberFunction
-
- sequentialSubscribers() - Method in class io.servicetalk.concurrent.api.TestCompletable.Builder
-
Allow sequential subscribers.
- sequentialSubscribers(SequentialCompletableSubscriberFunction) - Method in class io.servicetalk.concurrent.api.TestCompletable.Builder
-
- sequentialSubscribers() - Method in class io.servicetalk.concurrent.api.TestPublisher.Builder
-
Allow sequential subscribers.
- sequentialSubscribers(SequentialPublisherSubscriberFunction<T>) - Method in class io.servicetalk.concurrent.api.TestPublisher.Builder
-
- sequentialSubscribers() - Method in class io.servicetalk.concurrent.api.TestSingle.Builder
-
Allow sequential subscribers.
- sequentialSubscribers(SequentialSingleSubscriberFunction<T>) - Method in class io.servicetalk.concurrent.api.TestSingle.Builder
-
- SerializationException - Exception in io.servicetalk.serialization.api
-
Exception indicating an error during serialization or deserialization.
- SerializationException(String) - Constructor for exception io.servicetalk.serialization.api.SerializationException
-
New instance.
- SerializationException(String, Throwable) - Constructor for exception io.servicetalk.serialization.api.SerializationException
-
New instance.
- SerializationException(Throwable) - Constructor for exception io.servicetalk.serialization.api.SerializationException
-
New instance.
- SerializationException(String, Throwable, boolean, boolean) - Constructor for exception io.servicetalk.serialization.api.SerializationException
-
New instance.
- serializationProvider(Serializer, Consumer<HttpHeaders>, Predicate<HttpHeaders>) - Static method in class io.servicetalk.http.api.HttpSerializationProviders
-
- serializationProvider(SerializationProvider, Consumer<HttpHeaders>, Predicate<HttpHeaders>) - Static method in class io.servicetalk.http.api.HttpSerializationProviders
-
- SerializationProvider - Interface in io.servicetalk.serialization.api
-
A provider of serialization implementation for
Serializer
.
- serialize(T, Buffer) - Method in class io.servicetalk.data.jackson.JacksonSerializationProvider
-
- serialize(HttpHeaders, T, BufferAllocator) - Method in interface io.servicetalk.http.api.HttpSerializer
-
Serialize an object of type
T
into a
Buffer
.
- serialize(HttpHeaders, BlockingIterable<T>, BufferAllocator) - Method in interface io.servicetalk.http.api.HttpSerializer
-
- serialize(HttpHeaders, Publisher<T>, BufferAllocator) - Method in interface io.servicetalk.http.api.HttpSerializer
-
- serialize(HttpHeaders, HttpPayloadWriter<Buffer>, BufferAllocator) - Method in interface io.servicetalk.http.api.HttpSerializer
-
- serialize(Publisher<T>, BufferAllocator, Class<T>) - Method in class io.servicetalk.serialization.api.DefaultSerializer
-
- serialize(Iterable<T>, BufferAllocator, Class<T>) - Method in class io.servicetalk.serialization.api.DefaultSerializer
-
- serialize(BlockingIterable<T>, BufferAllocator, Class<T>) - Method in class io.servicetalk.serialization.api.DefaultSerializer
-
- serialize(Publisher<T>, BufferAllocator, Class<T>, IntUnaryOperator) - Method in class io.servicetalk.serialization.api.DefaultSerializer
-
- serialize(Iterable<T>, BufferAllocator, Class<T>, IntUnaryOperator) - Method in class io.servicetalk.serialization.api.DefaultSerializer
-
- serialize(BlockingIterable<T>, BufferAllocator, Class<T>, IntUnaryOperator) - Method in class io.servicetalk.serialization.api.DefaultSerializer
-
- serialize(Publisher<T>, BufferAllocator, TypeHolder<T>) - Method in class io.servicetalk.serialization.api.DefaultSerializer
-
- serialize(Iterable<T>, BufferAllocator, TypeHolder<T>) - Method in class io.servicetalk.serialization.api.DefaultSerializer
-
- serialize(BlockingIterable<T>, BufferAllocator, TypeHolder<T>) - Method in class io.servicetalk.serialization.api.DefaultSerializer
-
- serialize(Publisher<T>, BufferAllocator, TypeHolder<T>, IntUnaryOperator) - Method in class io.servicetalk.serialization.api.DefaultSerializer
-
- serialize(Iterable<T>, BufferAllocator, TypeHolder<T>, IntUnaryOperator) - Method in class io.servicetalk.serialization.api.DefaultSerializer
-
- serialize(BlockingIterable<T>, BufferAllocator, TypeHolder<T>, IntUnaryOperator) - Method in class io.servicetalk.serialization.api.DefaultSerializer
-
- serialize(T, BufferAllocator) - Method in class io.servicetalk.serialization.api.DefaultSerializer
-
- serialize(T, BufferAllocator, int) - Method in class io.servicetalk.serialization.api.DefaultSerializer
-
- serialize(T, Buffer) - Method in class io.servicetalk.serialization.api.DefaultSerializer
-
- serialize(T, Buffer) - Method in interface io.servicetalk.serialization.api.SerializationProvider
-
Serializes the passed object
toSerialize
to the passed
Buffer
.
- serialize(Publisher<T>, BufferAllocator, Class<T>) - Method in interface io.servicetalk.serialization.api.Serializer
-
Transforms the passed
Publisher
such that each contained element of type
T
is serialized into
a
Buffer
.
- serialize(Iterable<T>, BufferAllocator, Class<T>) - Method in interface io.servicetalk.serialization.api.Serializer
-
Transforms the passed
Iterable
such that each contained element of type
T
is serialized into
a
Buffer
.
- serialize(BlockingIterable<T>, BufferAllocator, Class<T>) - Method in interface io.servicetalk.serialization.api.Serializer
-
Transforms the passed
BlockingIterable
such that each contained element of type
T
is serialized
into a
Buffer
.
- serialize(Publisher<T>, BufferAllocator, Class<T>, IntUnaryOperator) - Method in interface io.servicetalk.serialization.api.Serializer
-
Transforms the passed
Publisher
such that each contained element of type
T
is serialized into
a
Buffer
.
- serialize(Iterable<T>, BufferAllocator, Class<T>, IntUnaryOperator) - Method in interface io.servicetalk.serialization.api.Serializer
-
Transforms the passed
Iterable
such that each contained element of type
T
is serialized into
a
Buffer
.
- serialize(BlockingIterable<T>, BufferAllocator, Class<T>, IntUnaryOperator) - Method in interface io.servicetalk.serialization.api.Serializer
-
Transforms the passed
BlockingIterable
such that each contained element of type
T
is serialized
into a
Buffer
.
- serialize(Publisher<T>, BufferAllocator, TypeHolder<T>) - Method in interface io.servicetalk.serialization.api.Serializer
-
Transforms the passed
Publisher
such that each contained element of type
T
is serialized into
a
Buffer
.
- serialize(Iterable<T>, BufferAllocator, TypeHolder<T>) - Method in interface io.servicetalk.serialization.api.Serializer
-
Transforms the passed
Iterable
such that each contained element of type
T
is serialized into
a
Buffer
.
- serialize(BlockingIterable<T>, BufferAllocator, TypeHolder<T>) - Method in interface io.servicetalk.serialization.api.Serializer
-
Transforms the passed
BlockingIterable
such that each contained element of type
T
is serialized
into a
Buffer
.
- serialize(Publisher<T>, BufferAllocator, TypeHolder<T>, IntUnaryOperator) - Method in interface io.servicetalk.serialization.api.Serializer
-
Transforms the passed
Publisher
such that each contained element of type
T
is serialized into
a
Buffer
.
- serialize(Iterable<T>, BufferAllocator, TypeHolder<T>, IntUnaryOperator) - Method in interface io.servicetalk.serialization.api.Serializer
-
Transforms the passed
Iterable
such that each contained element of type
T
is serialized into
a
Buffer
.
- serialize(BlockingIterable<T>, BufferAllocator, TypeHolder<T>, IntUnaryOperator) - Method in interface io.servicetalk.serialization.api.Serializer
-
Transforms the passed
BlockingIterable
such that each contained element of type
T
is serialized
into a
Buffer
.
- serialize(T, BufferAllocator) - Method in interface io.servicetalk.serialization.api.Serializer
-
Serializes the passed object
toSerialize
to the returned
Buffer
.
- serialize(T, BufferAllocator, int) - Method in interface io.servicetalk.serialization.api.Serializer
-
Serializes the passed object
toSerialize
to the returned
Buffer
.
- serialize(T, Buffer) - Method in interface io.servicetalk.serialization.api.Serializer
-
Serializes the passed object
toSerialize
to the passed
Buffer
.
- serialize(Object, Buffer) - Method in interface io.servicetalk.serialization.api.StreamingSerializer
-
Serializes the passed
Object
toSerialize
into the passed
Buffer
synchronously.
- Serializer - Interface in io.servicetalk.serialization.api
-
A contract for serialization and deserialization.
- serializerFor(GrpcMetadata, Class<T>) - Method in interface io.servicetalk.grpc.api.GrpcSerializationProvider
-
- serializerFor(Class<T>) - Method in interface io.servicetalk.http.api.HttpSerializationProvider
-
- serializerFor(Class<T>, IntUnaryOperator) - Method in interface io.servicetalk.http.api.HttpSerializationProvider
-
- serializerFor(TypeHolder<T>) - Method in interface io.servicetalk.http.api.HttpSerializationProvider
-
- serializerFor(TypeHolder<T>, IntUnaryOperator) - Method in interface io.servicetalk.http.api.HttpSerializationProvider
-
- SERVER - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"server"
- SERVER_CTX - Static variable in class io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest
-
- serverChannel(EventLoopGroup, Class<? extends SocketAddress>) - Static method in class io.servicetalk.transport.netty.internal.BuilderUtils
-
Returns the correct Class
to use with the given EventLoopGroup
.
- ServerContext - Interface in io.servicetalk.transport.api
-
Context for servers.
- serverHostAndPort(ServerContext) - Static method in class io.servicetalk.transport.netty.internal.AddressUtils
-
Returns a
HostAndPort
representation of server's listening address.
- serverNoOffloads() - Method in class io.servicetalk.http.router.jersey.AbstractResourceTest
-
- ServerSecurityConfig - Class in io.servicetalk.transport.netty.internal
-
Server security configuration.
- ServerSecurityConfig() - Constructor for class io.servicetalk.transport.netty.internal.ServerSecurityConfig
-
- ServerSecurityConfigurator - Interface in io.servicetalk.transport.api
-
- ServerSecurityConfigurator.ClientAuth - Enum in io.servicetalk.transport.api
-
Indicates the state of the SSLEngine
with respect to client authentication.
- SERVICE_UNAVAILABLE - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
503 Service Unavailable
- ServiceDiscoverer<UnresolvedAddress,ResolvedAddress,E extends ServiceDiscovererEvent<ResolvedAddress>> - Interface in io.servicetalk.client.api
-
Represents the interaction pattern with a service discovery system.
- serviceDiscoverer(ServiceDiscoverer<U, R, ? extends ServiceDiscovererEvent<R>>) - Method in class io.servicetalk.grpc.api.GrpcClientBuilder
-
- serviceDiscoverer(ServiceDiscoverer<U, R, ? extends ServiceDiscovererEvent<R>>) - Method in class io.servicetalk.http.api.MultiAddressHttpClientBuilder
-
- serviceDiscoverer(ServiceDiscoverer<U, R, ? extends PartitionedServiceDiscovererEvent<R>>) - Method in class io.servicetalk.http.api.PartitionedHttpClientBuilder
-
- serviceDiscoverer(ServiceDiscoverer<U, R, ? extends ServiceDiscovererEvent<R>>) - Method in class io.servicetalk.http.api.SingleAddressHttpClientBuilder
-
- ServiceDiscovererEvent<ResolvedAddress> - Interface in io.servicetalk.client.api
-
Notification from the Service Discovery system that availability for an address has changed.
- ServiceDiscovererTestSubscriber<T> - Class in io.servicetalk.client.servicediscoverer
-
- ServiceDiscovererTestSubscriber(CountDownLatch, AtomicReference<Throwable>, long) - Constructor for class io.servicetalk.client.servicediscoverer.ServiceDiscovererTestSubscriber
-
- ServiceDiscovererUtils - Class in io.servicetalk.client.api.internal
-
- ServiceDiscovererUtils.TwoIntsConsumer - Interface in io.servicetalk.client.api.internal
-
Represents an operation that accepts two int
-valued arguments and returns no result.
- serviceDiscoveryMaxQueueSize(int) - Method in class io.servicetalk.http.api.PartitionedHttpClientBuilder
-
- serviceInvocationStrategy() - Method in interface io.servicetalk.http.api.HttpApiConversions.ServiceAdapterHolder
-
- ServiceTalkAutoDiscoverable - Class in io.servicetalk.http.router.jersey.config
-
- ServiceTalkAutoDiscoverable() - Constructor for class io.servicetalk.http.router.jersey.config.ServiceTalkAutoDiscoverable
-
- ServiceTalkFeature - Class in io.servicetalk.http.router.jersey
-
Feature enabling ServiceTalk request handling.
- ServiceTalkFeature() - Constructor for class io.servicetalk.http.router.jersey.ServiceTalkFeature
-
- ServiceTalkJacksonSerializerAutoDiscoverable - Class in io.servicetalk.data.jackson.jersey.config
-
- ServiceTalkJacksonSerializerAutoDiscoverable() - Constructor for class io.servicetalk.data.jackson.jersey.config.ServiceTalkJacksonSerializerAutoDiscoverable
-
- ServiceTalkJacksonSerializerFeature - Class in io.servicetalk.data.jackson.jersey
-
Feature enabling ServiceTalk Jackson serializer request/response content handling.
- ServiceTalkJacksonSerializerFeature() - Constructor for class io.servicetalk.data.jackson.jersey.ServiceTalkJacksonSerializerFeature
-
- serviceTalkRequest(StreamingHttpRequest) - Method in class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- servicetalkRequestContext() - Method in class io.servicetalk.http.router.jersey.SynchronousResourceTest
-
- ServiceTalkSocketOptions - Class in io.servicetalk.transport.api
-
SocketOption
s that can be used beside StandardSocketOptions
.
- ServiceTalkTestTimeout - Class in io.servicetalk.concurrent.internal
-
Standard timeout shared by test classes.
- ServiceTalkTestTimeout() - Constructor for class io.servicetalk.concurrent.internal.ServiceTalkTestTimeout
-
- ServiceTalkTestTimeout(long, TimeUnit) - Constructor for class io.servicetalk.concurrent.internal.ServiceTalkTestTimeout
-
- ServiceTalkTestTimeout(long, TimeUnit, Runnable) - Constructor for class io.servicetalk.concurrent.internal.ServiceTalkTestTimeout
-
- ServiceTalkThreadContextMap - Class in io.servicetalk.log4j2.mdc.utils
-
A
ThreadContext
that provides storage for MDC based upon
AsyncContext
.
- ServiceTalkThreadContextMap() - Constructor for class io.servicetalk.log4j2.mdc.utils.ServiceTalkThreadContextMap
-
- ServiceTalkTracingThreadContextMap - Class in io.servicetalk.opentracing.log4j2
-
- ServiceTalkTracingThreadContextMap() - Constructor for class io.servicetalk.opentracing.log4j2.ServiceTalkTracingThreadContextMap
-
- serviceUnavailable() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- serviceUnavailable() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- serviceUnavailable() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- sessionCacheSize(long) - Method in interface io.servicetalk.grpc.api.GrpcClientSecurityConfigurator
-
- sessionCacheSize(long) - Method in interface io.servicetalk.grpc.api.GrpcServerSecurityConfigurator
-
- sessionCacheSize(long) - Method in interface io.servicetalk.http.api.HttpServerSecurityConfigurator
-
- sessionCacheSize(long) - Method in interface io.servicetalk.http.api.PartitionedHttpClientSecurityConfigurator
-
- sessionCacheSize(long) - Method in interface io.servicetalk.http.api.SingleAddressHttpClientSecurityConfigurator
-
- sessionCacheSize(long) - Method in interface io.servicetalk.transport.api.ClientSecurityConfigurator
-
- sessionCacheSize(long) - Method in interface io.servicetalk.transport.api.SecurityConfigurator
-
Set the size of the cache used for storing SSL session objects.
- sessionCacheSize(long) - Method in interface io.servicetalk.transport.api.ServerSecurityConfigurator
-
- sessionCacheSize(long) - Method in class io.servicetalk.transport.netty.internal.ClientSecurityConfig
-
Set the size of the cache used for storing SSL session objects.
- sessionCacheSize(long) - Method in class io.servicetalk.transport.netty.internal.ServerSecurityConfig
-
Set the size of the cache used for storing SSL session objects.
- sessionTimeout(long) - Method in interface io.servicetalk.grpc.api.GrpcClientSecurityConfigurator
-
- sessionTimeout(long) - Method in interface io.servicetalk.grpc.api.GrpcServerSecurityConfigurator
-
- sessionTimeout(long) - Method in interface io.servicetalk.http.api.HttpServerSecurityConfigurator
-
- sessionTimeout(long) - Method in interface io.servicetalk.http.api.PartitionedHttpClientSecurityConfigurator
-
- sessionTimeout(long) - Method in interface io.servicetalk.http.api.SingleAddressHttpClientSecurityConfigurator
-
- sessionTimeout(long) - Method in interface io.servicetalk.transport.api.ClientSecurityConfigurator
-
- sessionTimeout(long) - Method in interface io.servicetalk.transport.api.SecurityConfigurator
-
Set the timeout for the cached SSL session objects, in seconds.
- sessionTimeout(long) - Method in interface io.servicetalk.transport.api.ServerSecurityConfigurator
-
- sessionTimeout(long) - Method in class io.servicetalk.transport.netty.internal.ClientSecurityConfig
-
Set the timeout for the cached SSL session objects, in seconds.
- sessionTimeout(long) - Method in class io.servicetalk.transport.netty.internal.ServerSecurityConfig
-
Set the timeout for the cached SSL session objects, in seconds.
- set(CharSequence, CharSequence) - Method in class io.servicetalk.http.api.EmptyHttpHeaders
-
- set(CharSequence, Iterable<? extends CharSequence>) - Method in class io.servicetalk.http.api.EmptyHttpHeaders
-
- set(CharSequence, CharSequence...) - Method in class io.servicetalk.http.api.EmptyHttpHeaders
-
- set(HttpHeaders) - Method in class io.servicetalk.http.api.EmptyHttpHeaders
-
- set(CharSequence, CharSequence) - Method in interface io.servicetalk.http.api.HttpHeaders
-
Sets a header with the specified name
and value
.
- set(CharSequence, Iterable<? extends CharSequence>) - Method in interface io.servicetalk.http.api.HttpHeaders
-
Sets a new header with the specified name
and values
.
- set(CharSequence, Iterator<? extends CharSequence>) - Method in interface io.servicetalk.http.api.HttpHeaders
-
Sets a new header with the specified name
and values
.
- set(CharSequence, CharSequence...) - Method in interface io.servicetalk.http.api.HttpHeaders
-
Sets a header with the specified name
and values
.
- set(HttpHeaders) - Method in interface io.servicetalk.http.api.HttpHeaders
-
Clears the current header entries and copies all header entries of the specified headers
object.
- set(String) - Method in interface io.servicetalk.opentracing.inmemory.SingleLineValue
-
Sets the value.
- SET_COOKIE - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"set-cookie"
- SET_COOKIE2 - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"set-cookie2"
- setAnInt(int) - Method in class io.servicetalk.http.router.jersey.TestPojo
-
- setaString(String) - Method in class io.servicetalk.http.router.jersey.TestPojo
-
- setBoolean(int, boolean) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified boolean at the specified absolute index
in this
buffer.
- setBoolean(int, boolean) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setBoolean(int, boolean) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setByte(int, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified byte at the specified absolute index
in this
buffer.
- setByte(int, int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setByte(int, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setBytes(int, Buffer) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers the specified source buffer's data to this buffer starting at
the specified absolute index
until the source buffer becomes
unreadable.
- setBytes(int, Buffer, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers the specified source buffer's data to this buffer starting at
the specified absolute index
.
- setBytes(int, Buffer, int, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers the specified source buffer's data to this buffer starting at
the specified absolute index
.
- setBytes(int, byte[]) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers the specified source array's data to this buffer starting at
the specified absolute index
.
- setBytes(int, byte[], int, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers the specified source array's data to this buffer starting at
the specified absolute index
.
- setBytes(int, ByteBuffer) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers the specified source buffer's data to this buffer starting at
the specified absolute index
until the source buffer's position
reaches its limit.
- setBytes(int, InputStream, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers a fixed amount from the specified source InputStream's data to this buffer starting at
the specified absolute index
until length
bytes have been read, the end of stream
is reached, or an exception is thrown.
- setBytes(int, Buffer) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setBytes(int, Buffer, int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setBytes(int, Buffer, int, int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setBytes(int, byte[]) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setBytes(int, byte[], int, int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setBytes(int, ByteBuffer) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setBytes(int, Buffer) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setBytes(int, Buffer, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setBytes(int, Buffer, int, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setBytes(int, byte[]) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setBytes(int, byte[], int, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setBytes(int, ByteBuffer) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setBytes(int, InputStream, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setBytesUntilEndStream(int, InputStream, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers all the specified source InputStream's data to this buffer starting at
the specified absolute index
until the end of stream is reached or an exception is thrown.
- setBytesUntilEndStream(int, InputStream, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setChar(int, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 2-byte UTF-16 character at the specified absolute
index
in this buffer.
- setChar(int, int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setChar(int, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setCharsetUtf8(boolean) - Method in class io.servicetalk.http.utils.auth.BasicAuthHttpServiceFilter.Builder
-
Sets an advice for a user agent to use UTF-8
charset when it generates
user-id:password
pair.
- setDone() - Method in class io.servicetalk.concurrent.internal.ThreadInterruptingCancellable
-
- setDone(Throwable) - Method in class io.servicetalk.concurrent.internal.ThreadInterruptingCancellable
-
- setDouble(int, double) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 64-bit floating-point number at the specified
absolute index
in this buffer.
- setDouble(int, double) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setDouble(int, double) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setFloat(int, float) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 32-bit floating-point number at the specified
absolute index
in this buffer.
- setFloat(int, float) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setFloat(int, float) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setHeader(CharSequence, CharSequence) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- setHeader(CharSequence, CharSequence) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
- setHeader(CharSequence, CharSequence) - Method in class io.servicetalk.http.api.BlockingStreamingHttpServerResponse
-
- setHeader(CharSequence, CharSequence) - Method in interface io.servicetalk.http.api.HttpMetaData
-
Sets a header with the specified name
and value
.
- setHeader(CharSequence, CharSequence) - Method in interface io.servicetalk.http.api.HttpRequest
-
- setHeader(CharSequence, CharSequence) - Method in interface io.servicetalk.http.api.HttpRequestMetaData
-
- setHeader(CharSequence, CharSequence) - Method in interface io.servicetalk.http.api.HttpResponse
-
- setHeader(CharSequence, CharSequence) - Method in interface io.servicetalk.http.api.HttpResponseMetaData
-
- setHeader(CharSequence, CharSequence) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- setHeader(CharSequence, CharSequence) - Method in interface io.servicetalk.http.api.StreamingHttpResponse
-
- setHeaders(HttpHeaders) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- setHeaders(HttpHeaders) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
- setHeaders(HttpHeaders) - Method in class io.servicetalk.http.api.BlockingStreamingHttpServerResponse
-
- setHeaders(HttpHeaders) - Method in interface io.servicetalk.http.api.HttpMetaData
-
Clears the current header entries and copies all header entries of the specified headers
object.
- setHeaders(HttpHeaders) - Method in interface io.servicetalk.http.api.HttpRequest
-
- setHeaders(HttpHeaders) - Method in interface io.servicetalk.http.api.HttpRequestMetaData
-
- setHeaders(HttpHeaders) - Method in interface io.servicetalk.http.api.HttpResponse
-
- setHeaders(HttpHeaders) - Method in interface io.servicetalk.http.api.HttpResponseMetaData
-
- setHeaders(HttpHeaders) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- setHeaders(HttpHeaders) - Method in interface io.servicetalk.http.api.StreamingHttpResponse
-
- setInt(int, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 32-bit integer at the specified absolute
index
in this buffer.
- setInt(int, int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setInt(int, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setIntLE(int, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 32-bit integer at the specified absolute
index
in this buffer with Little Endian byte order
.
- setIntLE(int, int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setIntLE(int, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setLong(int, long) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 64-bit long integer at the specified absolute
index
in this buffer.
- setLong(int, long) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setLong(int, long) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setLongLE(int, long) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 64-bit long integer at the specified absolute
index
in this buffer in Little Endian Byte Order.
- setLongLE(int, long) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setLongLE(int, long) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setMedium(int, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 24-bit medium integer at the specified absolute
index
in this buffer.
- setMedium(int, int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setMedium(int, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setMediumLE(int, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 24-bit medium integer at the specified absolute
index
in this buffer in the Little Endian Byte Order.
- setMediumLE(int, int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setMediumLE(int, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setQueryParameter(String, String) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- setQueryParameter(String, String) - Method in interface io.servicetalk.http.api.HttpRequest
-
- setQueryParameter(String, String) - Method in interface io.servicetalk.http.api.HttpRequestMetaData
-
Sets a query parameter with the specified
key
and
value
, which will be
percent-encoded if needed.
- setQueryParameter(String, String) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- setQueryParameters(String, Iterable<String>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- setQueryParameters(String, String...) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- setQueryParameters(String, Iterable<String>) - Method in interface io.servicetalk.http.api.HttpRequest
-
- setQueryParameters(String, String...) - Method in interface io.servicetalk.http.api.HttpRequest
-
- setQueryParameters(String, Iterable<String>) - Method in interface io.servicetalk.http.api.HttpRequestMetaData
-
Sets new query parameters with the specified key
and values
.
- setQueryParameters(String, String...) - Method in interface io.servicetalk.http.api.HttpRequestMetaData
-
Sets new query parameters with the specified key
and values
.
- setQueryParameters(String, Iterable<String>) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- setQueryParameters(String, String...) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- setRequestCancellable(Cancellable, ContainerRequestContext) - Static method in class io.servicetalk.http.router.jersey.internal.RequestProperties
-
- setResponseBufferPublisher(Publisher<Buffer>, ContainerRequestContext) - Static method in class io.servicetalk.http.router.jersey.internal.RequestProperties
-
- setResponseExecutionStrategy(HttpExecutionStrategy, ContainerRequestContext) - Static method in class io.servicetalk.http.router.jersey.internal.RequestProperties
-
- setShort(int, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 16-bit short integer at the specified absolute
index
in this buffer.
- setShort(int, int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setShort(int, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setShortLE(int, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 16-bit short integer at the specified absolute
index
in this buffer with the Little Endian Byte Order.
- setShortLE(int, int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- setShortLE(int, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- setSystemId(String) - Method in class io.servicetalk.http.router.jersey.internal.SourceWrappers.PublisherSource
-
- setSystemId(String) - Method in class io.servicetalk.http.router.jersey.internal.SourceWrappers.SingleSource
-
- setTimeOutExpire() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- setTimeOutExpireHandled() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- setTimeOutResumed() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- setTimeOutResumeSuspended() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- setTrailer(CharSequence, CharSequence) - Method in class io.servicetalk.http.api.HttpOutputStream
-
- setTrailer(CharSequence, CharSequence) - Method in interface io.servicetalk.http.api.HttpPayloadWriter
-
- setTrailer(CharSequence, CharSequence) - Method in interface io.servicetalk.http.api.HttpRequest
-
- setTrailer(CharSequence, CharSequence) - Method in interface io.servicetalk.http.api.HttpResponse
-
- setTrailers(HttpHeaders) - Method in class io.servicetalk.http.api.HttpOutputStream
-
- setTrailers(HttpHeaders) - Method in interface io.servicetalk.http.api.HttpPayloadWriter
-
- setTrailers(HttpHeaders) - Method in interface io.servicetalk.http.api.HttpRequest
-
- setTrailers(HttpHeaders) - Method in interface io.servicetalk.http.api.HttpResponse
-
- setUp() - Method in class io.servicetalk.http.api.AbstractHttpServiceFilterTest
-
- setup() - Method in class io.servicetalk.http.router.jersey.CancellationTest
-
- setupContext() - Method in class io.servicetalk.http.api.AbstractHttpRequesterFilterTest
-
- shouldFlushOnUnwritable() - Method in class io.servicetalk.transport.netty.internal.DelegatingFlushStrategy
-
- shouldFlushOnUnwritable() - Method in interface io.servicetalk.transport.netty.internal.FlushStrategy
-
Returns true
if pending writes, if any, MUST be flushed when the connection is not writable.
- shouldFlushOnUnwritable() - Method in class io.servicetalk.transport.netty.internal.SplittingFlushStrategy
-
- SignalOffloader - Interface in io.servicetalk.concurrent.internal
-
A contract to offload
signals to and
from any asynchronous source.
- SignalOffloaderFactory - Interface in io.servicetalk.concurrent.internal
-
- SignalOffloaders - Class in io.servicetalk.concurrent.internal
-
- Single<T> - Class in io.servicetalk.concurrent.api
-
An asynchronous computation that either completes with success giving the result or completes with an error.
- Single() - Constructor for class io.servicetalk.concurrent.api.Single
-
New instance.
- single() - Static method in class io.servicetalk.transport.netty.internal.ExecutionContextRule
-
- single(ThreadFactory) - Static method in class io.servicetalk.transport.netty.internal.ExecutionContextRule
-
- SingleAddressHttpClientBuilder<U,R> - Class in io.servicetalk.http.api
-
A builder of
StreamingHttpClient
instances which call a single server based on the provided unresolved
address.
- SingleAddressHttpClientBuilder() - Constructor for class io.servicetalk.http.api.SingleAddressHttpClientBuilder
-
- SingleAddressHttpClientSecurityConfigurator<U,R> - Interface in io.servicetalk.http.api
-
- singleBufferResponse() - Method in class io.servicetalk.http.router.jersey.ExceptionMapperTest
-
- SingleLineFormatter - Class in io.servicetalk.opentracing.inmemory
-
Single-line serialization format.
- SingleLineValue - Interface in io.servicetalk.opentracing.inmemory
-
Wrapper for supporting injecting and extracting single-string values.
- singleMapResponse() - Method in class io.servicetalk.http.router.jersey.ExceptionMapperTest
-
- SingleOperator<T,R> - Interface in io.servicetalk.concurrent.api
-
An operator contract for a
Single
.
- singleResources() - Method in class io.servicetalk.http.router.jersey.AbstractFilterInterceptorTest
-
- SingleSource<T> - Interface in io.servicetalk.concurrent
-
An asynchronous computation that either completes with success giving the result or completes with an error.
- SingleSource(Single<T>) - Constructor for class io.servicetalk.http.router.jersey.internal.SourceWrappers.SingleSource
-
- SingleSource.Processor<T,R> - Interface in io.servicetalk.concurrent
-
- SingleSource.Subscriber<T> - Interface in io.servicetalk.concurrent
-
- singleSubscriber() - Method in class io.servicetalk.concurrent.api.TestCompletable.Builder
-
Allow only a single subscriber.
- singleSubscriber(NonResubscribeableCompletableSubscriberFunction) - Method in class io.servicetalk.concurrent.api.TestCompletable.Builder
-
- singleSubscriber() - Method in class io.servicetalk.concurrent.api.TestPublisher.Builder
-
Allow only a single subscriber.
- singleSubscriber(NonResubscribeablePublisherSubscriberFunction<T>) - Method in class io.servicetalk.concurrent.api.TestPublisher.Builder
-
- singleSubscriber() - Method in class io.servicetalk.concurrent.api.TestSingle.Builder
-
Allow only a single subscriber.
- singleSubscriber(NonResubscribeableSingleSubscriberFunction<T>) - Method in class io.servicetalk.concurrent.api.TestSingle.Builder
-
- SingleTerminalSignalConsumer<T> - Interface in io.servicetalk.concurrent.api
-
A contract that provides discrete callbacks for various ways in which a SingleSource.Subscriber
can
terminate.
- singletonBlockingIterable(T) - Static method in class io.servicetalk.concurrent.internal.BlockingIterables
-
- SingletonDnsServerAddresses - Class in io.servicetalk.dns.discovery.netty
-
- SingletonDnsServerAddresses(InetSocketAddress) - Constructor for class io.servicetalk.dns.discovery.netty.SingletonDnsServerAddresses
-
Create a new instance.
- SingletonDnsServerAddressStreamProvider - Class in io.servicetalk.dns.discovery.netty
-
- SingletonDnsServerAddressStreamProvider(DnsServerAddressStream) - Constructor for class io.servicetalk.dns.discovery.netty.SingletonDnsServerAddressStreamProvider
-
Create a new instance.
- size() - Method in interface io.servicetalk.client.api.partition.PartitionAttributes
-
Determine how many key/value pairs are contained in this collection.
- size() - Method in interface io.servicetalk.concurrent.api.AsyncContextMap
-
- size() - Method in interface io.servicetalk.dns.discovery.netty.DnsServerAddressStream
-
- size() - Method in class io.servicetalk.dns.discovery.netty.SingletonDnsServerAddresses
-
- size() - Method in class io.servicetalk.http.api.EmptyHttpHeaders
-
- size() - Method in interface io.servicetalk.http.api.HttpHeaders
-
Returns the number of headers in this object.
- skipBytes(int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Increases the current readerIndex
by the specified
length
in this buffer.
- skipBytes(int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- skipBytes(int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- slice() - Method in interface io.servicetalk.buffer.api.Buffer
-
Returns a slice of this buffer's readable bytes.
- slice(int, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Returns a slice of this buffer's sub-region.
- slice() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- slice(int, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- sniHostname(String) - Method in interface io.servicetalk.grpc.api.GrpcClientSecurityConfigurator
-
- sniHostname(String) - Method in interface io.servicetalk.http.api.PartitionedHttpClientSecurityConfigurator
-
- sniHostname(String) - Method in interface io.servicetalk.http.api.SingleAddressHttpClientSecurityConfigurator
-
- sniHostname(String) - Method in interface io.servicetalk.transport.api.ClientSecurityConfigurator
-
- sniHostname(String) - Method in class io.servicetalk.transport.netty.internal.ClientSecurityConfig
-
- sniHostname - Variable in class io.servicetalk.transport.netty.internal.ReadOnlyClientSecurityConfig
-
- sniHostname() - Method in class io.servicetalk.transport.netty.internal.ReadOnlyClientSecurityConfig
-
Returns the SNI host name.
- socketChannel(EventLoopGroup, Class<? extends SocketAddress>) - Static method in class io.servicetalk.transport.netty.internal.BuilderUtils
-
Returns the correct Class
to use with the given EventLoopGroup
.
- socketChannel(EventLoopGroup, FileDescriptorSocketAddress) - Static method in class io.servicetalk.transport.netty.internal.BuilderUtils
-
Returns the correct Channel that wraps the given filedescriptor or null
if not supported.
- socketOption(SocketOption<T>, T) - Method in class io.servicetalk.grpc.api.GrpcClientBuilder
-
- socketOption(SocketOption<T>, T) - Method in class io.servicetalk.grpc.api.GrpcServerBuilder
-
Add a SocketOption
that is applied.
- socketOption(SocketOption<T>) - Method in class io.servicetalk.http.api.DelegatingHttpServiceContext
-
- socketOption(SocketOption<T>, T) - Method in class io.servicetalk.http.api.HttpServerBuilder
-
Adds a SocketOption
that is applied.
- socketOption(SocketOption<T>, T) - Method in class io.servicetalk.http.api.MultiAddressHttpClientBuilder
-
- socketOption(SocketOption<T>, T) - Method in class io.servicetalk.http.api.PartitionedHttpClientBuilder
-
- socketOption(SocketOption<T>, T) - Method in class io.servicetalk.http.api.SingleAddressHttpClientBuilder
-
- socketOption(SocketOption<T>) - Method in class io.servicetalk.http.api.TestHttpServiceContext
-
- socketOption(SocketOption<T>) - Method in interface io.servicetalk.transport.api.ConnectionContext
-
- socketOption(SocketOption<T>) - Method in class io.servicetalk.transport.api.DelegatingConnectionContext
-
- socketOption(SocketOption<T>) - Method in class io.servicetalk.transport.netty.internal.DefaultNettyConnection
-
- SocketOptionUtils - Class in io.servicetalk.transport.netty.internal
-
Utilities to convert SocketOption
s.
- SourceAdapters - Class in io.servicetalk.concurrent.api
-
A set of adapter methods to convert an asynchronous source in this module to a corresponding source in
io.servicetalk.concurrent
module.
- SourceWrappers - Class in io.servicetalk.http.router.jersey.internal
-
When request's contents are not buffered, Jersey's determines if the entity body input stream that backs a request
can be closed by introspecting the return type of the MessageBodyReader
.
- SourceWrappers.PublisherSource<T> - Class in io.servicetalk.http.router.jersey.internal
-
- SourceWrappers.SingleSource<T> - Class in io.servicetalk.http.router.jersey.internal
-
A
Single
that is also a
Source
.
- span() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemoryScope
-
- SPAN_ID - Static variable in class io.servicetalk.opentracing.internal.ZipkinHeaderNames
-
- spanId() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpan
-
Returns the span ID.
- spanIdHex() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemoryTraceState
-
The hex representation of the traceId.
- spanIdHex() - Method in class io.servicetalk.opentracing.inmemory.DefaultInMemoryTraceState
-
- specExceptions() - Method in interface io.servicetalk.http.netty.H1ProtocolConfig
-
Additional exceptions for
HTTP/1.1 specification.
- specExceptions(H1SpecExceptions) - Method in class io.servicetalk.http.netty.H1ProtocolConfigBuilder
-
Sets additional exceptions for
HTTP/1.1 specification.
- spliterator() - Method in interface io.servicetalk.concurrent.BlockingIterable
-
- spliterator() - Method in interface io.servicetalk.http.api.HttpHeaders
-
- SplittingFlushStrategy - Class in io.servicetalk.transport.netty.internal
-
A
FlushStrategy
that splits writes into logical write boundaries and manages flush state across those logical
write boundaries.
- SplittingFlushStrategy(FlushStrategy, SplittingFlushStrategy.FlushBoundaryProvider) - Constructor for class io.servicetalk.transport.netty.internal.SplittingFlushStrategy
-
Create a new instance.
- SplittingFlushStrategy.FlushBoundaryProvider - Interface in io.servicetalk.transport.netty.internal
-
- SplittingFlushStrategy.FlushBoundaryProvider.FlushBoundary - Enum in io.servicetalk.transport.netty.internal
-
- sse(SseEventSink, Sse) - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.ResourceUnsupportedAsync
-
- sseBroadcast() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- sseSinkClosedLatch - Variable in class io.servicetalk.http.router.jersey.resources.CancellableResources
-
- sseStream() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- sseUnsupported() - Method in class io.servicetalk.http.router.jersey.AsynchronousResourceTest
-
- SslClientChannelInitializer - Class in io.servicetalk.transport.netty.internal
-
- SslClientChannelInitializer(SslContext, String, String, int, boolean) - Constructor for class io.servicetalk.transport.netty.internal.SslClientChannelInitializer
-
New instance.
- sslContext() - Method in class io.servicetalk.tcp.netty.internal.ReadOnlyTcpClientConfig
-
- sslContext() - Method in class io.servicetalk.tcp.netty.internal.ReadOnlyTcpServerConfig
-
- SslContextFactory - Class in io.servicetalk.transport.netty.internal
-
A factory for creating SslContext
s.
- sslHostnameVerificationAlgorithm() - Method in class io.servicetalk.tcp.netty.internal.ReadOnlyTcpClientConfig
-
Returns the hostname verification algorithm, if any.
- sslHostnameVerificationHost() - Method in class io.servicetalk.tcp.netty.internal.ReadOnlyTcpClientConfig
-
Get the non-authoritative name of the host.
- sslHostnameVerificationPort() - Method in class io.servicetalk.tcp.netty.internal.ReadOnlyTcpClientConfig
-
Get the non-authoritative port.
- SslServerChannelInitializer - Class in io.servicetalk.transport.netty.internal
-
- SslServerChannelInitializer(SslContext) - Constructor for class io.servicetalk.transport.netty.internal.SslServerChannelInitializer
-
New instance.
- SslServerChannelInitializer(DomainNameMapping<SslContext>) - Constructor for class io.servicetalk.transport.netty.internal.SslServerChannelInitializer
-
New instance.
- sslSession() - Method in class io.servicetalk.http.api.AbstractHttpRequesterFilterTest
-
- sslSession() - Method in class io.servicetalk.http.api.AbstractHttpServiceFilterTest
-
- sslSession() - Method in class io.servicetalk.http.api.DelegatingHttpServiceContext
-
- sslSession() - Method in class io.servicetalk.http.api.TestHttpServiceContext
-
- sslSession() - Method in interface io.servicetalk.transport.api.ConnectionContext
-
Get the SSLSession
for this connection.
- sslSession() - Method in class io.servicetalk.transport.api.DelegatingConnectionContext
-
- sslSession() - Method in class io.servicetalk.transport.netty.internal.DefaultNettyConnection
-
- stableAccumulated(int) - Static method in class io.servicetalk.log4j2.mdc.utils.LoggerStringWriter
-
- stableAccumulated(int, long) - Static method in class io.servicetalk.log4j2.mdc.utils.LoggerStringWriter
-
- StacklessClosedChannelException - Exception in io.servicetalk.transport.netty.internal
-
ClosedChannelException
that will not not fill in the stacktrace but use a cheaper way of producing
limited stacktrace details for the user.
- start() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpanBuilder
-
- startActive(boolean) - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpanBuilder
-
- startEpochMicros() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpan
-
Returns the starting epoch in milliseconds.
- startManual() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpanBuilder
-
- StatelessTrailersTransformer<Payload> - Class in io.servicetalk.http.api
-
- StatelessTrailersTransformer() - Constructor for class io.servicetalk.http.api.StatelessTrailersTransformer
-
- status() - Method in enum io.servicetalk.grpc.api.GrpcStatusCode
-
Returns a standard
GrpcStatus
with this status code.
- status() - Method in exception io.servicetalk.grpc.api.GrpcStatusException
-
- status(HttpResponseStatus) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
- status(HttpResponseStatus) - Method in class io.servicetalk.http.api.BlockingStreamingHttpServerResponse
-
- status(HttpResponseStatus) - Method in interface io.servicetalk.http.api.HttpResponse
-
- status() - Method in interface io.servicetalk.http.api.HttpResponseMetaData
-
- status(HttpResponseStatus) - Method in interface io.servicetalk.http.api.HttpResponseMetaData
-
- status() - Method in exception io.servicetalk.http.netty.ProxyResponseException
-
- statusClass() - Method in class io.servicetalk.http.api.HttpResponseStatus
-
- strategy() - Method in class io.servicetalk.grpc.api.DefaultGrpcClientMetadata
-
- strategy() - Method in interface io.servicetalk.grpc.api.GrpcClientMetadata
-
- StrategyInfluencerChainBuilder - Class in io.servicetalk.http.api
-
- StrategyInfluencerChainBuilder() - Constructor for class io.servicetalk.http.api.StrategyInfluencerChainBuilder
-
Creates a new instance.
- StreamingDeserializer<T> - Interface in io.servicetalk.serialization.api
-
A contract capable of deserializing a stream of
Buffer
s into a stream of
T
s.
- StreamingHttpClient - Interface in io.servicetalk.http.api
-
- StreamingHttpClientFilter - Class in io.servicetalk.http.api
-
- StreamingHttpClientFilter(FilterableStreamingHttpClient) - Constructor for class io.servicetalk.http.api.StreamingHttpClientFilter
-
Create a new instance.
- StreamingHttpClientFilterFactory - Interface in io.servicetalk.http.api
-
- StreamingHttpConnection - Interface in io.servicetalk.http.api
-
- StreamingHttpConnectionFilter - Class in io.servicetalk.http.api
-
- StreamingHttpConnectionFilter(FilterableStreamingHttpConnection) - Constructor for class io.servicetalk.http.api.StreamingHttpConnectionFilter
-
Create a new instance.
- StreamingHttpConnectionFilterFactory - Interface in io.servicetalk.http.api
-
- StreamingHttpRequest - Interface in io.servicetalk.http.api
-
- StreamingHttpRequester - Interface in io.servicetalk.http.api
-
- StreamingHttpRequestFactory - Interface in io.servicetalk.http.api
-
- StreamingHttpRequestResponseFactory - Interface in io.servicetalk.http.api
-
- StreamingHttpRequests - Class in io.servicetalk.http.api
-
- StreamingHttpResponse - Interface in io.servicetalk.http.api
-
- StreamingHttpResponseFactory - Interface in io.servicetalk.http.api
-
- StreamingHttpResponses - Class in io.servicetalk.http.api
-
- StreamingHttpService - Interface in io.servicetalk.http.api
-
A service contract for the HTTP protocol.
- StreamingHttpServiceFilter - Class in io.servicetalk.http.api
-
- StreamingHttpServiceFilter(StreamingHttpService) - Constructor for class io.servicetalk.http.api.StreamingHttpServiceFilter
-
New instance.
- StreamingHttpServiceFilterFactory - Interface in io.servicetalk.http.api
-
- streamingResponseFactory() - Method in class io.servicetalk.http.api.HttpServiceContext
-
- streamingResponseFactory() - Method in class io.servicetalk.http.api.TestHttpServiceContext
-
- streamingRouteFor(String) - Method in interface io.servicetalk.grpc.api.GrpcRoutes.AllGrpcRoutes
-
- StreamingSerializer - Interface in io.servicetalk.serialization.api
-
A contract capable of serializing a stream of
Object
s into a stream of
Buffer
s.
- StringMultiValueMatcher - Interface in io.servicetalk.http.router.predicate.dsl
-
Extends
CookieMatcher
for things where the value is a string, like headers and query parameters.
- stringResponse() - Method in class io.servicetalk.http.router.jersey.ExceptionMapperTest
-
- submit(Runnable) - Method in class io.servicetalk.concurrent.api.DelegatingExecutor
-
- submit(Callable<? extends T>) - Method in class io.servicetalk.concurrent.api.DelegatingExecutor
-
- submit(Runnable) - Method in interface io.servicetalk.concurrent.api.Executor
-
Create a new
Completable
that executes the passed
Runnable
on each subscribe.
- submit(Callable<? extends T>) - Method in interface io.servicetalk.concurrent.api.Executor
-
Creates a new
Single
that creates and executes the passed
Callable
when subscribed to.
- submitCallable(Supplier<? extends Callable<? extends T>>) - Method in class io.servicetalk.concurrent.api.DelegatingExecutor
-
- submitCallable(Supplier<? extends Callable<? extends T>>) - Method in interface io.servicetalk.concurrent.api.Executor
-
Create a new
Single
that obtains a
Callable
from
callableSupplier
and executes on each
subscribe.
- submitRunnable(Supplier<Runnable>) - Method in class io.servicetalk.concurrent.api.DelegatingExecutor
-
- submitRunnable(Supplier<Runnable>) - Method in interface io.servicetalk.concurrent.api.Executor
-
Creates a new
Completable
that creates and executes a
Runnable
when subscribed to.
- subResourceDefault() - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.AbstractExecutionStrategyResource
-
- subResourceDefaultPubMapped(Publisher<Buffer>) - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.AbstractExecutionStrategyResource
-
- subResourceDefaultSingle() - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.AbstractExecutionStrategyResource
-
- subResourceDefaultSingleBuffer() - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.AbstractExecutionStrategyResource
-
- subResourceDefaultSingleMapped(Single<Buffer>) - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.AbstractExecutionStrategyResource
-
- subResourceDefaultSingleResponse() - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.AbstractExecutionStrategyResource
-
- subResourceRouteExecId() - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.AbstractExecutionStrategyResource
-
- subResourceRouteExecIdPubMapped(Publisher<Buffer>) - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.AbstractExecutionStrategyResource
-
- subResourceRouteExecIdSingle() - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.AbstractExecutionStrategyResource
-
- subResourceRouteExecIdSingleBuffer() - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.AbstractExecutionStrategyResource
-
- subResourceRouteExecIdSingleMapped(Single<Buffer>) - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.AbstractExecutionStrategyResource
-
- subResourceRouteExecIdSingleResponse() - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.AbstractExecutionStrategyResource
-
- subResourceRouteNoOffloads() - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.AbstractExecutionStrategyResource
-
- subResourceRouteNoOffloadsPubMapped(Publisher<Buffer>) - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.AbstractExecutionStrategyResource
-
- subResourceRouteNoOffloadsSingle() - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.AbstractExecutionStrategyResource
-
- subResourceRouteNoOffloadsSingleBuffer() - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.AbstractExecutionStrategyResource
-
- subResourceRouteNoOffloadsSingleMapped(Single<Buffer>) - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.AbstractExecutionStrategyResource
-
- subResourceRouteNoOffloadsSingleResponse() - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.AbstractExecutionStrategyResource
-
- SubscribableCompletable - Class in io.servicetalk.concurrent.api.internal
-
- SubscribableCompletable() - Constructor for class io.servicetalk.concurrent.api.internal.SubscribableCompletable
-
- SubscribablePublisher<T> - Class in io.servicetalk.concurrent.api.internal
-
- SubscribablePublisher() - Constructor for class io.servicetalk.concurrent.api.internal.SubscribablePublisher
-
- SubscribableSingle<T> - Class in io.servicetalk.concurrent.api.internal
-
- SubscribableSingle() - Constructor for class io.servicetalk.concurrent.api.internal.SubscribableSingle
-
- subscribe() - Method in class io.servicetalk.concurrent.api.Completable
-
- subscribe(Runnable) - Method in class io.servicetalk.concurrent.api.Completable
-
- subscribe(CompletableSource.Subscriber) - Method in class io.servicetalk.concurrent.api.internal.SubscribableCompletable
-
- subscribe(PublisherSource.Subscriber<? super T>) - Method in class io.servicetalk.concurrent.api.internal.SubscribablePublisher
-
- subscribe(SingleSource.Subscriber<? super T>) - Method in class io.servicetalk.concurrent.api.internal.SubscribableSingle
-
- subscribe(Consumer<? super T>) - Method in class io.servicetalk.concurrent.api.Single
-
- subscribe(CompletableSource.Subscriber) - Method in class io.servicetalk.concurrent.api.TestCompletable
-
- subscribe(PublisherSource.Subscriber<? super T>) - Method in class io.servicetalk.concurrent.api.TestPublisher
-
- subscribe(SingleSource.Subscriber<? super T>) - Method in class io.servicetalk.concurrent.api.TestSingle
-
- subscribe(CompletableSource.Subscriber) - Method in interface io.servicetalk.concurrent.CompletableSource
-
Subscribes to the outcome of this CompletableSource
.
- subscribe(PublisherSource.Subscriber<? super T>) - Method in interface io.servicetalk.concurrent.PublisherSource
-
Subscribe for the result(s) of this PublisherSource
.
- subscribe(SingleSource.Subscriber<? super T>) - Method in interface io.servicetalk.concurrent.SingleSource
-
Subscribe for the result of this SingleSource
.
- subscribeInternal(CompletableSource.Subscriber) - Method in class io.servicetalk.concurrent.api.Completable
-
- subscribeInternal(PublisherSource.Subscriber<? super T>) - Method in class io.servicetalk.concurrent.api.Publisher
-
- subscribeInternal(SingleSource.Subscriber<? super T>) - Method in class io.servicetalk.concurrent.api.Single
-
- subscribeOn(Executor) - Method in class io.servicetalk.concurrent.api.Completable
-
- subscribeOn(Executor) - Method in class io.servicetalk.concurrent.api.Publisher
-
- subscribeOn(Executor) - Method in class io.servicetalk.concurrent.api.Single
-
- subscribeOnOverride(Executor) - Method in class io.servicetalk.concurrent.api.Completable
-
- subscribeOnOverride(Executor) - Method in class io.servicetalk.concurrent.api.Publisher
-
- subscribeOnOverride(Executor) - Method in class io.servicetalk.concurrent.api.Single
-
- subscriber() - Method in class io.servicetalk.concurrent.api.SequentialCompletableSubscriberFunction
-
- subscriber() - Method in class io.servicetalk.concurrent.api.SequentialPublisherSubscriberFunction
-
- subscriber() - Method in class io.servicetalk.concurrent.api.SequentialSingleSubscriberFunction
-
- subscribers() - Method in class io.servicetalk.concurrent.api.ConcurrentCompletableSubscriberFunction
-
- subscribers() - Method in class io.servicetalk.concurrent.api.ConcurrentPublisherSubscriberFunction
-
- subscribers() - Method in class io.servicetalk.concurrent.api.ConcurrentSingleSubscriberFunction
-
- SubscriberUtils - Class in io.servicetalk.concurrent.internal
-
- subscribeShareContext() - Method in class io.servicetalk.concurrent.api.Completable
-
- subscribeShareContext() - Method in class io.servicetalk.concurrent.api.Publisher
-
- subscribeShareContext() - Method in class io.servicetalk.concurrent.api.Single
-
Signifies that when the returned
Single
is subscribed to, the
AsyncContext
will be shared
instead of making a
copy
.
- subscription() - Method in class io.servicetalk.concurrent.api.TestPublisherSubscriber
-
- subscriptionReceived() - Method in class io.servicetalk.concurrent.api.TestPublisherSubscriber
-
Returns true
if #onSubscribe(Subscription)
has been called, false
otherwise.
- subtractIfPositive(long, long) - Static method in class io.servicetalk.concurrent.internal.FlowControlUtils
-
Subtract y
from x
if x
is positive.
- succeeded(T) - Static method in class io.servicetalk.concurrent.api.Single
-
Creates a realized
Single
which always completes successfully with the provided
value
.
- suspended(AsyncResponse) - Method in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources.ResourceUnsupportedAsync
-
- swapAndCopyCumulation(ByteBuf, ByteBuf) - Method in class io.servicetalk.transport.netty.internal.ByteToMessageDecoder
-
Swap the existing cumulation
ByteBuf
for a new ByteBuf
and copy in
.
- SWITCHING_PROTOCOLS - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
101 Switching Protocols
- switchingProtocols() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- switchingProtocols() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- switchingProtocols() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- synchronousResource() - Method in class io.servicetalk.http.router.jersey.AbstractFilterInterceptorTest
-
- SynchronousResources - Class in io.servicetalk.http.router.jersey.resources
-
Synchronous (in JAX-RS lingo [1]) resources.
- SynchronousResources() - Constructor for class io.servicetalk.http.router.jersey.resources.SynchronousResources
-
- SynchronousResourceTest - Class in io.servicetalk.http.router.jersey
-
- SynchronousResourceTest(boolean, AbstractNonParameterizedJerseyStreamingHttpServiceTest.RouterApi) - Constructor for class io.servicetalk.http.router.jersey.SynchronousResourceTest
-
- tags() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpan
-
Returns an unmodifiable view of the tags.
- takeAtMost(long) - Method in class io.servicetalk.concurrent.api.Publisher
-
Takes at most
numElements
elements from
this
Publisher
.
- takeError() - Method in class io.servicetalk.concurrent.api.TestCompletableSubscriber
-
- takeError() - Method in class io.servicetalk.concurrent.api.TestPublisherSubscriber
-
- takeError() - Method in class io.servicetalk.concurrent.api.TestSingleSubscriber
-
- takeItems() - Method in class io.servicetalk.concurrent.api.TestPublisherSubscriber
-
- takeOnNext() - Method in class io.servicetalk.concurrent.api.TestCollectingPublisherSubscriber
-
- takeResult() - Method in class io.servicetalk.concurrent.api.TestSingleSubscriber
-
- takeTerminal() - Method in class io.servicetalk.concurrent.api.TestCompletableSubscriber
-
- takeTerminal() - Method in class io.servicetalk.concurrent.api.TestPublisherSubscriber
-
- takeUntil(Completable) - Method in class io.servicetalk.concurrent.api.Publisher
-
Takes elements until
Completable
is terminated successfully or with failure.
- takeWhile(Predicate<? super T>) - Method in class io.servicetalk.concurrent.api.Publisher
-
- taskBasedOffloaderFactory() - Static method in class io.servicetalk.concurrent.internal.SignalOffloaders
-
- TcpClient - Class in io.servicetalk.tcp.netty.internal
-
A utility to create a TCP clients for tests.
- TcpClient() - Constructor for class io.servicetalk.tcp.netty.internal.TcpClient
-
New instance with default configuration.
- TcpClient(TcpClientConfig) - Constructor for class io.servicetalk.tcp.netty.internal.TcpClient
-
New instance.
- TcpClientChannelInitializer - Class in io.servicetalk.tcp.netty.internal
-
- TcpClientChannelInitializer(ReadOnlyTcpClientConfig) - Constructor for class io.servicetalk.tcp.netty.internal.TcpClientChannelInitializer
-
- TcpClientChannelInitializer(ReadOnlyTcpClientConfig, boolean) - Constructor for class io.servicetalk.tcp.netty.internal.TcpClientChannelInitializer
-
- TcpClientConfig - Class in io.servicetalk.tcp.netty.internal
-
Configuration for TCP based clients.
- TcpClientConfig() - Constructor for class io.servicetalk.tcp.netty.internal.TcpClientConfig
-
New instance.
- TcpClientConfig(TcpClientConfig) - Constructor for class io.servicetalk.tcp.netty.internal.TcpClientConfig
-
Copy constructor.
- TcpConnector - Class in io.servicetalk.tcp.netty.internal
-
Utility class for TCP clients to connect.
- TcpServer - Class in io.servicetalk.tcp.netty.internal
-
A utility to create a TCP server for tests.
- TcpServer() - Constructor for class io.servicetalk.tcp.netty.internal.TcpServer
-
New instance with default configuration.
- TcpServer(TcpServerConfig) - Constructor for class io.servicetalk.tcp.netty.internal.TcpServer
-
New instance.
- TcpServerBinder - Class in io.servicetalk.tcp.netty.internal
-
Utility class to start a TCP based server.
- TcpServerChannelInitializer - Class in io.servicetalk.tcp.netty.internal
-
- TcpServerChannelInitializer(ReadOnlyTcpServerConfig) - Constructor for class io.servicetalk.tcp.netty.internal.TcpServerChannelInitializer
-
- TcpServerConfig - Class in io.servicetalk.tcp.netty.internal
-
Configuration for TCP based servers.
- TcpServerConfig() - Constructor for class io.servicetalk.tcp.netty.internal.TcpServerConfig
-
- TE - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"te"
- TEMPORARY_REDIRECT - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
307 Temporary Redirect (since HTTP/1.1)
- temporaryRedirect() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- temporaryRedirect() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- temporaryRedirect() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- terminal() - Method in class io.servicetalk.concurrent.api.TestCompletableSubscriber
-
- terminal() - Method in class io.servicetalk.concurrent.api.TestPublisherSubscriber
-
- TerminalNotification - Class in io.servicetalk.concurrent.internal
-
Holder of Throwable
.
- TerminalSignalConsumer - Interface in io.servicetalk.concurrent.api
-
A contract that provides discrete callbacks for various ways in which a PublisherSource.Subscriber
or a
CompletableSource.Subscriber
can terminate.
- terminate() - Method in interface io.servicetalk.concurrent.api.BlockingProcessorSignalsHolder
-
Terminates this holder, such that no further modifications of this holder are expected.
- terminate(Throwable) - Method in interface io.servicetalk.concurrent.api.BlockingProcessorSignalsHolder
-
Terminates this holder, such that no further modifications of this holder are expected.
- terminate() - Method in interface io.servicetalk.concurrent.api.PublisherProcessorSignalsHolder
-
Terminates this holder, such that no further modifications of this holder are allowed.
- terminate(Throwable) - Method in interface io.servicetalk.concurrent.api.PublisherProcessorSignalsHolder
-
Terminates this holder, such that no further modifications of this holder are allowed.
- terminate(PublisherSource.Subscriber<?>) - Method in class io.servicetalk.concurrent.internal.TerminalNotification
-
Invoke PublisherSource.Subscriber#onComplete()
or PublisherSource.Subscriber#onError(Throwable)
on the passed subscriber
.
- terminate(PublisherSource.Subscriber<?>, Throwable) - Method in class io.servicetalk.concurrent.internal.TerminalNotification
-
Invoke
PublisherSource.Subscriber#onError(Throwable)
with the passed
Throwable
if this
TerminalNotification
is for completion.
- terminate(CompletableSource.Subscriber, Throwable) - Method in class io.servicetalk.concurrent.internal.TerminalNotification
-
- terminate(CompletableSource.Subscriber) - Method in class io.servicetalk.concurrent.internal.TerminalNotification
-
- test(int, T) - Method in interface io.servicetalk.concurrent.api.BiIntPredicate
-
Evaluates this predicate on the given arguments.
- TEST_EXEC - Static variable in class io.servicetalk.http.router.jersey.ExecutionStrategyConfigurationFailuresTest
-
- TestApplication() - Constructor for class io.servicetalk.http.router.jersey.AbstractResourceTest.TestApplication
-
- TestApplication() - Constructor for class io.servicetalk.http.router.jersey.ExceptionMapperTest.TestApplication
-
- TestApplication() - Constructor for class io.servicetalk.http.router.jersey.ExecutionStrategyTest.TestApplication
-
- TestApplication() - Constructor for class io.servicetalk.http.router.jersey.GlobalFiltersTest.TestApplication
-
- TestApplication() - Constructor for class io.servicetalk.http.router.jersey.IllBehavedRequestFilterTest.TestApplication
-
- TestApplication() - Constructor for class io.servicetalk.http.router.jersey.InputConsumingGlobalFiltersTest.TestApplication
-
- TestApplication() - Constructor for class io.servicetalk.http.router.jersey.InterceptorsTest.TestApplication
-
- TestApplication() - Constructor for class io.servicetalk.http.router.jersey.SecurityFilterTest.TestApplication
-
- TestCancellable - Class in io.servicetalk.concurrent.api
-
- TestCancellable() - Constructor for class io.servicetalk.concurrent.api.TestCancellable
-
- TestCollectingCompletableSubscriber - Class in io.servicetalk.concurrent.api
-
- TestCollectingCompletableSubscriber() - Constructor for class io.servicetalk.concurrent.api.TestCollectingCompletableSubscriber
-
- TestCollectingPublisherSubscriber<T> - Class in io.servicetalk.concurrent.api
-
- TestCollectingPublisherSubscriber() - Constructor for class io.servicetalk.concurrent.api.TestCollectingPublisherSubscriber
-
- TestCompletable - Class in io.servicetalk.concurrent.api
-
- TestCompletable() - Constructor for class io.servicetalk.concurrent.api.TestCompletable
-
Create a TestCompletable
with the defaults.
- TestCompletable.Builder - Class in io.servicetalk.concurrent.api
-
- TestCompletableSubscriber - Class in io.servicetalk.concurrent.api
-
- TestCompletableSubscriber() - Constructor for class io.servicetalk.concurrent.api.TestCompletableSubscriber
-
Create a TestCompletableSubscriber
with the defaults.
- TestCompletableSubscriber.Builder - Class in io.servicetalk.concurrent.api
-
- TestExceptionMapper() - Constructor for class io.servicetalk.http.router.jersey.ExceptionMapperTest.TestExceptionMapper
-
- TestExecutor - Class in io.servicetalk.concurrent.api
-
An
Executor
implementation that provides methods for controlling execution of queued and schedules tasks,
for testing.
- TestExecutor() - Constructor for class io.servicetalk.concurrent.api.TestExecutor
-
Create a new instance.
- TestFilter() - Constructor for class io.servicetalk.http.router.jersey.AbstractResourceTest.TestFilter
-
- TestGlobalFilter() - Constructor for class io.servicetalk.http.router.jersey.AbstractFilterInterceptorTest.TestGlobalFilter
-
- TestGlobalInterceptor() - Constructor for class io.servicetalk.http.router.jersey.AbstractFilterInterceptorTest.TestGlobalInterceptor
-
- TestHttpServiceContext - Class in io.servicetalk.http.api
-
- TestHttpServiceContext(HttpHeadersFactory, StreamingHttpRequestResponseFactory, HttpExecutionContext) - Constructor for class io.servicetalk.http.api.TestHttpServiceContext
-
- TestInputConsumingGlobalFilter() - Constructor for class io.servicetalk.http.router.jersey.AbstractFilterInterceptorTest.TestInputConsumingGlobalFilter
-
- TestIterableToBlockingIterable<T> - Class in io.servicetalk.concurrent.api
-
- TestIterableToBlockingIterable(Iterable<T>, BiConsumer<Long, TimeUnit>, BiConsumer<Long, TimeUnit>, AutoCloseable) - Constructor for class io.servicetalk.concurrent.api.TestIterableToBlockingIterable
-
- TestPojo - Class in io.servicetalk.http.router.jersey
-
- TestPojo() - Constructor for class io.servicetalk.http.router.jersey.TestPojo
-
- TestPublisher<T> - Class in io.servicetalk.concurrent.api
-
- TestPublisher() - Constructor for class io.servicetalk.concurrent.api.TestPublisher
-
Create a TestPublisher
with the defaults.
- TestPublisher.Builder<T> - Class in io.servicetalk.concurrent.api
-
- TestPublisherSubscriber<T> - Class in io.servicetalk.concurrent.api
-
- TestPublisherSubscriber() - Constructor for class io.servicetalk.concurrent.api.TestPublisherSubscriber
-
Create a TestPublisherSubscriber
with the defaults.
- TestPublisherSubscriber.Builder<T> - Class in io.servicetalk.concurrent.api
-
- testResource() - Method in class io.servicetalk.http.router.jersey.ExecutionStrategyTest
-
- TestSecurityFilter() - Constructor for class io.servicetalk.http.router.jersey.SecurityFilterTest.TestSecurityFilter
-
- TestSingle<T> - Class in io.servicetalk.concurrent.api
-
- TestSingle() - Constructor for class io.servicetalk.concurrent.api.TestSingle
-
Create a TestSingle
with the defaults.
- TestSingle.Builder<T> - Class in io.servicetalk.concurrent.api
-
Allows for creating
TestSingle
s with non-default settings.
- TestSingleSubscriber<T> - Class in io.servicetalk.concurrent.api
-
- TestSingleSubscriber() - Constructor for class io.servicetalk.concurrent.api.TestSingleSubscriber
-
Create a TestSingleSubscriber
with the defaults.
- TestSingleSubscriber.Builder<T> - Class in io.servicetalk.concurrent.api
-
- TestStreamingHttpClient - Class in io.servicetalk.http.api
-
- TestStreamingHttpConnection - Class in io.servicetalk.http.api
-
- TestSubscription - Class in io.servicetalk.concurrent.api
-
- TestSubscription() - Constructor for class io.servicetalk.concurrent.api.TestSubscription
-
- testUri(String) - Method in class io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest
-
- testUri(String) - Method in class io.servicetalk.http.router.jersey.AbstractResourceTest
-
- testUri(String) - Method in class io.servicetalk.http.router.jersey.MixedModeResourceTest
-
- TestUtils - Class in io.servicetalk.http.router.jersey
-
- TestUtils.ContentReadException - Exception in io.servicetalk.http.router.jersey
-
- TEXT_PLAIN - Static variable in class io.servicetalk.http.api.HttpHeaderValues
-
"text/plain"
- TEXT_PLAIN_UTF_8 - Static variable in class io.servicetalk.http.api.HttpHeaderValues
-
"text/plain"
- textDeserializer() - Static method in class io.servicetalk.http.api.HttpSerializationProviders
-
Creates an
HttpDeserializer
that can deserialize
String
s with
StandardCharsets.UTF_8
Charset
.
- textDeserializer(Charset) - Static method in class io.servicetalk.http.api.HttpSerializationProviders
-
Creates an
HttpDeserializer
that can deserialize
String
s with the specified
Charset
.
- textDeserializer(Charset, Predicate<HttpHeaders>) - Static method in class io.servicetalk.http.api.HttpSerializationProviders
-
Creates an
HttpDeserializer
that can deserialize
String
s with the specified
Charset
.
- textSerializer() - Static method in class io.servicetalk.http.api.HttpSerializationProviders
-
Creates an
HttpSerializer
that can serialize
String
s with
StandardCharsets.UTF_8
Charset
.
- textSerializer(Charset) - Static method in class io.servicetalk.http.api.HttpSerializationProviders
-
Creates an
HttpSerializer
that can serialize
String
s with the specified
Charset
.
- textSerializer(Charset, Consumer<HttpHeaders>) - Static method in class io.servicetalk.http.api.HttpSerializationProviders
-
Creates an
HttpSerializer
that can serialize
String
s with the specified
Charset
.
- thenRouteTo(StreamingHttpService) - Method in interface io.servicetalk.http.router.predicate.dsl.RouteContinuation
-
Completes the route by specifying the
StreamingHttpService
to route requests to that match the previously
specified criteria.
- thenRouteTo(HttpService) - Method in interface io.servicetalk.http.router.predicate.dsl.RouteContinuation
-
Completes the route by specifying the
HttpService
to route requests to that match the
previously specified criteria.
- thenRouteTo(BlockingHttpService) - Method in interface io.servicetalk.http.router.predicate.dsl.RouteContinuation
-
Completes the route by specifying the
BlockingHttpService
to route requests to that match the
previously specified criteria.
- thenRouteTo(BlockingStreamingHttpService) - Method in interface io.servicetalk.http.router.predicate.dsl.RouteContinuation
-
- THREAD_NAME - Static variable in class io.servicetalk.http.router.jersey.resources.ExecutionStrategyResources
-
- THREAD_PREFIX - Static variable in class io.servicetalk.concurrent.internal.ServiceTalkTestTimeout
-
- threadBasedOffloaderFactory() - Static method in class io.servicetalk.concurrent.internal.SignalOffloaders
-
- ThreadInterruptingCancellable - Class in io.servicetalk.concurrent.internal
-
- ThreadInterruptingCancellable(Thread) - Constructor for class io.servicetalk.concurrent.internal.ThreadInterruptingCancellable
-
Create a new instance.
- ThrowableUtils - Class in io.servicetalk.concurrent.internal
-
Utility for creating static Throwable
s.
- throwException(Throwable) - Static method in class io.servicetalk.utils.internal.PlatformDependent
-
Raises an exception bypassing compiler checks for checked exceptions.
- timeout - Variable in class io.servicetalk.http.api.AbstractHttpRequesterFilterTest
-
- timeout - Variable in class io.servicetalk.http.api.AbstractHttpServiceFilterTest
-
- timeout - Variable in class io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest
-
- timeout - Variable in class io.servicetalk.http.router.jersey.CancellationTest
-
- TimeoutHttpRequesterFilter - Class in io.servicetalk.http.utils
-
A filter to enable timeouts for HTTP requests.
- TimeoutHttpRequesterFilter(Duration) - Constructor for class io.servicetalk.http.utils.TimeoutHttpRequesterFilter
-
Creates a new instance.
- TimeoutHttpRequesterFilter(Duration, Executor) - Constructor for class io.servicetalk.http.utils.TimeoutHttpRequesterFilter
-
Creates a new instance.
- timer(long, TimeUnit) - Method in class io.servicetalk.concurrent.api.DelegatingExecutor
-
- timer(Duration) - Method in class io.servicetalk.concurrent.api.DelegatingExecutor
-
- timer(long, TimeUnit) - Method in interface io.servicetalk.concurrent.api.Executor
-
Creates a new
Completable
that will complete after the time duration expires.
- timer(Duration) - Method in interface io.servicetalk.concurrent.api.Executor
-
Creates a new
Completable
that will complete after the time duration expires.
- to(Consumer<String>) - Static method in interface io.servicetalk.opentracing.inmemory.SingleLineValue
-
- toAsyncCloseable(AsyncCloseables.CloseableResource) - Static method in class io.servicetalk.concurrent.api.AsyncCloseables
-
- toBlockingClient(StreamingHttpClient, HttpExecutionStrategyInfluencer) - Static method in class io.servicetalk.http.api.HttpApiConversions
-
- toBlockingConnection(StreamingHttpConnection, HttpExecutionStrategyInfluencer) - Static method in class io.servicetalk.http.api.HttpApiConversions
-
- toBlockingHttpService(StreamingHttpService) - Static method in class io.servicetalk.http.api.HttpApiConversions
-
- toBlockingStreamingClient(StreamingHttpClient, HttpExecutionStrategyInfluencer) - Static method in class io.servicetalk.http.api.HttpApiConversions
-
- toBlockingStreamingConnection(StreamingHttpConnection, HttpExecutionStrategyInfluencer) - Static method in class io.servicetalk.http.api.HttpApiConversions
-
- toBlockingStreamingHttpService(StreamingHttpService) - Static method in class io.servicetalk.http.api.HttpApiConversions
-
- toBlockingStreamingRequest() - Method in interface io.servicetalk.http.api.HttpRequest
-
- toBlockingStreamingRequest() - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- toBlockingStreamingResponse() - Method in interface io.servicetalk.http.api.HttpResponse
-
- toBlockingStreamingResponse() - Method in interface io.servicetalk.http.api.StreamingHttpResponse
-
- toByteBuf(Buffer) - Static method in class io.servicetalk.buffer.netty.BufferUtils
-
Return a ByteBuf
for the given buffer.
- toByteBufNoThrow(Buffer) - Static method in class io.servicetalk.buffer.netty.BufferUtils
-
Converts the passed buffer
to ByteBuf
, or returns null
if not possible.
- toClient(StreamingHttpClient, HttpExecutionStrategyInfluencer) - Static method in class io.servicetalk.http.api.HttpApiConversions
-
- toCompletable() - Method in class io.servicetalk.concurrent.api.Single
-
Ignores the result of this
Single
and forwards the termination signal to the returned
Completable
.
- toCompletionStage() - Method in class io.servicetalk.concurrent.api.Completable
-
Converts this Completable
to a CompletionStage
.
- toCompletionStage() - Method in class io.servicetalk.concurrent.api.Publisher
-
Convert this
Publisher
into a
CompletionStage
with a
Collection
containing the elements
of this
Publisher
upon successful termination.
- toCompletionStage(Supplier<? extends R>, BiFunction<? super R, ? super T, R>) - Method in class io.servicetalk.concurrent.api.Publisher
-
Convert this
Publisher
into a
CompletionStage
of type
R
which represents all elements of
this
Publisher
upon successful termination.
- toCompletionStage() - Method in class io.servicetalk.concurrent.api.Single
-
Convert this
Single
to a
CompletionStage
.
- toConnection(StreamingHttpConnection, HttpExecutionStrategyInfluencer) - Static method in class io.servicetalk.http.api.HttpApiConversions
-
- toEventLoopAwareNettyIoExecutor(IoExecutor) - Static method in class io.servicetalk.transport.netty.internal.EventLoopAwareNettyIoExecutors
-
- toFuture() - Method in class io.servicetalk.concurrent.api.Completable
-
Converts this Completable
to a Future
.
- toFuture() - Method in class io.servicetalk.concurrent.api.Publisher
-
Convert this
Publisher
into a
Future
with a
Collection
containing the elements of this
Publisher
upon successful termination.
- toFuture(Supplier<? extends R>, BiFunction<? super R, ? super T, R>) - Method in class io.servicetalk.concurrent.api.Publisher
-
Convert this
Publisher
into a
Future
of type
R
which represents all elements of this
Publisher
upon successful termination.
- toFuture() - Method in class io.servicetalk.concurrent.api.Single
-
Convert this
Single
to a
Future
.
- toHttpService(StreamingHttpService) - Static method in class io.servicetalk.http.api.HttpApiConversions
-
- toInputStream(Function<? super T, byte[]>) - Method in class io.servicetalk.concurrent.api.Publisher
-
- toInputStream(Function<? super T, byte[]>, int) - Method in class io.servicetalk.concurrent.api.Publisher
-
- toIterable() - Method in class io.servicetalk.concurrent.api.Publisher
-
- toIterable(int) - Method in class io.servicetalk.concurrent.api.Publisher
-
- toListenableAsyncCloseable(AsyncCloseable) - Static method in class io.servicetalk.concurrent.api.AsyncCloseables
-
- toListenableAsyncCloseable(AsyncCloseable, Function<Completable, Completable>) - Static method in class io.servicetalk.concurrent.api.AsyncCloseables
-
- toLoadBalancedConnection(FilterableStreamingHttpConnection) - Method in interface io.servicetalk.http.api.HttpLoadBalancerFactory
-
- toLoadBalancedConnection(FilterableStreamingHttpConnection) - Method in class io.servicetalk.http.netty.DefaultHttpLoadBalancerFactory
-
- toNettyAddress(Object) - Static method in class io.servicetalk.transport.netty.internal.BuilderUtils
-
If address
if a ServiceTalk specific address it is unwrapped into a Netty address.
- toNettyIoExecutor(IoExecutor) - Static method in class io.servicetalk.transport.netty.internal.NettyIoExecutors
-
- toNioBuffer() - Method in interface io.servicetalk.buffer.api.Buffer
-
Exposes this buffer's readable bytes as an NIO ByteBuffer
.
- toNioBuffer(int, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Exposes this buffer's sub-region as an NIO ByteBuffer
.
- toNioBuffer() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- toNioBuffer(int, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- toNioBuffers() - Method in interface io.servicetalk.buffer.api.Buffer
-
Exposes this buffer's readable bytes as an NIO ByteBuffer
's.
- toNioBuffers(int, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Exposes this buffer's bytes as an NIO ByteBuffer
's for the specified index and length
The returned buffer shares the content with this buffer, while changing the position and limit
of the returned NIO buffer does not affect the indexes of this buffer.
- toNioBuffers() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- toNioBuffers(int, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- TOO_EARLY - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
425 Too Early
- TOO_MANY_REQUESTS - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
429 Too Many Requests
- tooEarly() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- tooEarly() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- tooEarly() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- tooManyRequests() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- tooManyRequests() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- tooManyRequests() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- toPublisher() - Method in class io.servicetalk.concurrent.api.Completable
-
- toPublisher() - Method in class io.servicetalk.concurrent.api.Single
-
- toReactiveStreamsPublisher(Publisher<T>) - Static method in class io.servicetalk.concurrent.reactivestreams.ReactiveStreamsAdapters
-
- toReactiveStreamsPublisher(PublisherSource<T>) - Static method in class io.servicetalk.concurrent.reactivestreams.ReactiveStreamsAdapters
-
- toRequest() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- toRequest() - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- toReservedBlockingConnection(ReservedStreamingHttpConnection, HttpExecutionStrategyInfluencer) - Static method in class io.servicetalk.http.api.HttpApiConversions
-
- toReservedBlockingStreamingConnection(ReservedStreamingHttpConnection, HttpExecutionStrategyInfluencer) - Static method in class io.servicetalk.http.api.HttpApiConversions
-
- toReservedConnection(ReservedStreamingHttpConnection, HttpExecutionStrategyInfluencer) - Static method in class io.servicetalk.http.api.HttpApiConversions
-
- toResolvedInetSocketAddress(HostAndPort) - Static method in class io.servicetalk.transport.netty.internal.BuilderUtils
-
Converts
HostAndPort
that contains a resolved address into
InetSocketAddress
.
- toResponse() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
- toResponse() - Method in interface io.servicetalk.http.api.StreamingHttpResponse
-
- toResponse(Throwable) - Method in class io.servicetalk.http.router.jersey.ExceptionMapperTest.TestExceptionMapper
-
- toSingle() - Method in class io.servicetalk.concurrent.api.Completable
-
Converts this
Completable
to a
Single
.
- toSource(Publisher<T>) - Static method in class io.servicetalk.concurrent.api.SourceAdapters
-
- toSource(Single<T>) - Static method in class io.servicetalk.concurrent.api.SourceAdapters
-
- toSource(Completable) - Static method in class io.servicetalk.concurrent.api.SourceAdapters
-
- toStreamingHttpService(HttpService, HttpExecutionStrategyInfluencer) - Static method in class io.servicetalk.http.api.HttpApiConversions
-
- toStreamingHttpService(BlockingStreamingHttpService, HttpExecutionStrategyInfluencer) - Static method in class io.servicetalk.http.api.HttpApiConversions
-
- toStreamingHttpService(BlockingHttpService, HttpExecutionStrategyInfluencer) - Static method in class io.servicetalk.http.api.HttpApiConversions
-
- toStreamingRequest() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- toStreamingRequest() - Method in interface io.servicetalk.http.api.HttpRequest
-
- toStreamingResponse() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
- toStreamingResponse() - Method in interface io.servicetalk.http.api.HttpResponse
-
- toString() - Method in interface io.servicetalk.buffer.api.Buffer
-
Returns the string representation of this buffer.
- toString(Charset) - Method in interface io.servicetalk.buffer.api.Buffer
-
Decodes this buffer's readable bytes into a string with the specified
character set name.
- toString(int, int, Charset) - Method in interface io.servicetalk.buffer.api.Buffer
-
Decodes this buffer's sub-region into a string with the specified
character set.
- toString(Charset) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- toString(int, int, Charset) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- toString() - Method in class io.servicetalk.client.api.DefaultServiceDiscovererEvent
-
- toString() - Method in class io.servicetalk.client.api.partition.PartitionAttributes.Key
-
- toString() - Method in class io.servicetalk.concurrent.api.AsyncContextMap.Key
-
- toString() - Method in class io.servicetalk.concurrent.api.GroupedPublisher
-
- toString() - Method in class io.servicetalk.concurrent.api.TestSubscription
-
- toString() - Method in class io.servicetalk.concurrent.internal.TerminalNotification
-
- toString() - Method in class io.servicetalk.dns.discovery.netty.SingletonDnsServerAddresses
-
- toString() - Method in class io.servicetalk.grpc.api.GrpcStatus
-
- toString() - Method in class io.servicetalk.http.api.DefaultHttpCookiePair
-
- toString() - Method in class io.servicetalk.http.api.DefaultHttpSetCookie
-
- toString() - Method in class io.servicetalk.http.api.EmptyHttpHeaders
-
- toString(BiFunction<? super CharSequence, ? super CharSequence, CharSequence>) - Method in class io.servicetalk.http.api.EmptyHttpHeaders
-
- toString() - Method in class io.servicetalk.http.api.HttpEventKey
-
- toString() - Method in interface io.servicetalk.http.api.HttpHeaders
-
- toString(BiFunction<? super CharSequence, ? super CharSequence, CharSequence>) - Method in interface io.servicetalk.http.api.HttpHeaders
-
Builds a string which represents all the content in this
HttpHeaders
in which sensitive headers can be
filtered via
filter
.
- toString() - Method in interface io.servicetalk.http.api.HttpMetaData
-
Returns a string representation of the message.
- toString(BiFunction<? super CharSequence, ? super CharSequence, CharSequence>) - Method in interface io.servicetalk.http.api.HttpMetaData
-
Returns a string representation of the message and headers.
- toString() - Method in class io.servicetalk.http.api.HttpProtocolVersion
-
- toString() - Method in class io.servicetalk.http.api.HttpRequestMethod
-
- toString() - Method in class io.servicetalk.http.api.HttpResponseStatus
-
- toString() - Method in class io.servicetalk.http.api.ReservedStreamingHttpConnectionFilter
-
- toString() - Method in class io.servicetalk.http.api.StreamingHttpClientFilter
-
- toString() - Method in class io.servicetalk.http.api.StreamingHttpConnectionFilter
-
- toString() - Method in exception io.servicetalk.http.netty.ProxyResponseException
-
- toString() - Method in class io.servicetalk.http.security.auth.basic.jersey.BasicAuthPrincipal
-
- toString() - Method in class io.servicetalk.transport.api.DomainSocketAddress
-
- toString() - Method in class io.servicetalk.transport.api.FileDescriptorSocketAddress
-
- toString() - Method in class io.servicetalk.transport.netty.internal.DefaultNettyConnection
-
- trace(String) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequestFactory
-
- trace(String) - Method in interface io.servicetalk.http.api.HttpRequestFactory
-
- TRACE - Static variable in class io.servicetalk.http.api.HttpRequestMethod
-
- trace(String) - Method in interface io.servicetalk.http.api.StreamingHttpRequestFactory
-
- TRACE_ID - Static variable in class io.servicetalk.opentracing.internal.ZipkinHeaderNames
-
- traceId() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpan
-
Returns the low 64 bits of trace ID.
- traceIdHex() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemoryTraceState
-
The hex representation of the traceId.
- traceIdHex() - Method in class io.servicetalk.opentracing.inmemory.DefaultInMemoryTraceState
-
- traceIdHigh() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpan
-
Returns the high 64 bits for 128-bit trace IDs, or 0L
for 64-bit trace IDs.
- traceState() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpanContext
-
- TracingConstants - Class in io.servicetalk.opentracing.internal
-
Various constants for tracing.
- TracingHttpRequesterFilter - Class in io.servicetalk.opentracing.http
-
An HTTP filter that supports open tracing.
- TracingHttpRequesterFilter(Tracer, String) - Constructor for class io.servicetalk.opentracing.http.TracingHttpRequesterFilter
-
Create a new instance.
- TracingHttpRequesterFilter(Tracer, String, boolean) - Constructor for class io.servicetalk.opentracing.http.TracingHttpRequesterFilter
-
Create a new instance.
- TracingHttpServiceFilter - Class in io.servicetalk.opentracing.http
-
- TracingHttpServiceFilter(Tracer, String) - Constructor for class io.servicetalk.opentracing.http.TracingHttpServiceFilter
-
Create a new instance.
- TracingHttpServiceFilter(Tracer, String, boolean) - Constructor for class io.servicetalk.opentracing.http.TracingHttpServiceFilter
-
Create a new instance.
- TRAILER - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"trailer"
- TRAILERS - Static variable in class io.servicetalk.http.api.HttpHeaderValues
-
"trailers"
- trailers() - Method in interface io.servicetalk.http.api.LastHttpMetaData
-
- trailersEncodedSizeEstimate() - Method in interface io.servicetalk.http.netty.H1ProtocolConfig
-
Value used to calculate an exponential moving average of the encoded size of the HTTP
trailer fields for a guess for future
buffer allocations.
- trailersEncodedSizeEstimate(int) - Method in class io.servicetalk.http.netty.H1ProtocolConfigBuilder
-
Sets the value used to calculate an exponential moving average of the encoded size of the HTTP
trailer fields for a guess for future
buffer allocations.
- TrailersTransformer<State,Payload> - Interface in io.servicetalk.http.api
-
A contract for transforming trailers for a streaming HTTP request/response.
- TRANSFER_ENCODING - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"transfer-encoding"
- transform(TrailersTransformer<T, Buffer>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- transform(TrailersTransformer<T, Buffer>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
- transform(TrailersTransformer<T, Buffer>) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- transform(TrailersTransformer<T, Buffer>) - Method in interface io.servicetalk.http.api.StreamingHttpResponse
-
- transformPayloadBody(Function<BlockingIterable<Buffer>, BlockingIterable<T>>, HttpSerializer<T>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- transformPayloadBody(Function<BlockingIterable<T>, BlockingIterable<R>>, HttpDeserializer<T>, HttpSerializer<R>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- transformPayloadBody(UnaryOperator<BlockingIterable<Buffer>>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- transformPayloadBody(Function<BlockingIterable<Buffer>, BlockingIterable<T>>, HttpSerializer<T>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
- transformPayloadBody(Function<BlockingIterable<T>, BlockingIterable<R>>, HttpDeserializer<T>, HttpSerializer<R>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
- transformPayloadBody(UnaryOperator<BlockingIterable<Buffer>>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
- transformPayloadBody(Function<Publisher<Buffer>, Publisher<T>>, HttpSerializer<T>) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
Returns a
StreamingHttpRequest
with its underlying payload transformed to the result of serialization.
- transformPayloadBody(Function<Publisher<T>, Publisher<R>>, HttpDeserializer<T>, HttpSerializer<R>) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
Returns a
StreamingHttpRequest
with its underlying payload transformed to the result of serialization.
- transformPayloadBody(UnaryOperator<Publisher<Buffer>>) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- transformPayloadBody(Function<Publisher<Buffer>, Publisher<T>>, HttpSerializer<T>) - Method in interface io.servicetalk.http.api.StreamingHttpResponse
-
- transformPayloadBody(Function<Publisher<T>, Publisher<R>>, HttpDeserializer<T>, HttpSerializer<R>) - Method in interface io.servicetalk.http.api.StreamingHttpResponse
-
- transformPayloadBody(UnaryOperator<Publisher<Buffer>>) - Method in interface io.servicetalk.http.api.StreamingHttpResponse
-
- transformRaw(TrailersTransformer<T, Object>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- transformRaw(TrailersTransformer<T, Object>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
- transformRaw(TrailersTransformer<T, Object>) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
Returns a
StreamingHttpRequest
with its underlying payload transformed to
Object
s,
with access to the trailers.
- transformRaw(TrailersTransformer<T, Object>) - Method in interface io.servicetalk.http.api.StreamingHttpResponse
-
Returns a
StreamingHttpResponse
with its underlying payload transformed to
Object
s,
with access to the trailers.
- transformRawPayloadBody(UnaryOperator<BlockingIterable<?>>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- transformRawPayloadBody(UnaryOperator<BlockingIterable<?>>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
- transformRawPayloadBody(UnaryOperator<Publisher<?>>) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- transformRawPayloadBody(UnaryOperator<Publisher<?>>) - Method in interface io.servicetalk.http.api.StreamingHttpResponse
-
- translatedException() - Method in class io.servicetalk.http.router.jersey.AbstractResourceTest
-
- transportError() - Method in class io.servicetalk.transport.netty.internal.DefaultNettyConnection
-
- transportError() - Method in interface io.servicetalk.transport.netty.internal.NettyConnectionContext
-
Returns a
Single
<
Throwable
> that may terminate with an error, if an error is observed at
the transport.
- transportEventIterable(HttpEventKey<T>) - Method in interface io.servicetalk.http.api.BlockingHttpConnection
-
- transportEventIterable(HttpEventKey<T>) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpConnection
-
Returns a
BlockingIterable
that gives the current value of the setting as well as subsequent changes to
the setting value as long as the
PublisherSource.Subscriber
has expressed enough demand.
- transportEventStream(HttpEventKey<T>) - Method in interface io.servicetalk.http.api.FilterableStreamingHttpConnection
-
Returns a
Publisher
that gives the current value of a transport event as well as subsequent changes to
the event value as long as the
PublisherSource.Subscriber
has expressed enough demand.
- transportEventStream(HttpEventKey<T>) - Method in interface io.servicetalk.http.api.HttpConnection
-
Returns a
Publisher
that gives the current value of a transport event as well as subsequent changes to
the event value as long as the
PublisherSource.Subscriber
has expressed enough demand.
- transportEventStream(HttpEventKey<T>) - Method in class io.servicetalk.http.api.ReservedStreamingHttpConnectionFilter
-
- transportEventStream(HttpEventKey<T>) - Method in class io.servicetalk.http.api.StreamingHttpConnectionFilter
-
- trustManager(Supplier<InputStream>) - Method in interface io.servicetalk.grpc.api.GrpcClientSecurityConfigurator
-
- trustManager(TrustManagerFactory) - Method in interface io.servicetalk.grpc.api.GrpcClientSecurityConfigurator
-
- trustManager(Supplier<InputStream>) - Method in interface io.servicetalk.grpc.api.GrpcServerSecurityConfigurator
-
- trustManager(TrustManagerFactory) - Method in interface io.servicetalk.grpc.api.GrpcServerSecurityConfigurator
-
- trustManager(Supplier<InputStream>) - Method in interface io.servicetalk.http.api.HttpServerSecurityConfigurator
-
- trustManager(TrustManagerFactory) - Method in interface io.servicetalk.http.api.HttpServerSecurityConfigurator
-
- trustManager(Supplier<InputStream>) - Method in interface io.servicetalk.http.api.PartitionedHttpClientSecurityConfigurator
-
- trustManager(TrustManagerFactory) - Method in interface io.servicetalk.http.api.PartitionedHttpClientSecurityConfigurator
-
- trustManager(Supplier<InputStream>) - Method in interface io.servicetalk.http.api.SingleAddressHttpClientSecurityConfigurator
-
- trustManager(TrustManagerFactory) - Method in interface io.servicetalk.http.api.SingleAddressHttpClientSecurityConfigurator
-
- trustManager(Supplier<InputStream>) - Method in interface io.servicetalk.transport.api.ClientSecurityConfigurator
-
- trustManager(TrustManagerFactory) - Method in interface io.servicetalk.transport.api.ClientSecurityConfigurator
-
- trustManager(Supplier<InputStream>) - Method in interface io.servicetalk.transport.api.SecurityConfigurator
-
Trusted certificates for verifying the remote endpoint's certificate.
- trustManager(TrustManagerFactory) - Method in interface io.servicetalk.transport.api.SecurityConfigurator
-
Trust manager for verifying the remote endpoint's certificate.
- trustManager(Supplier<InputStream>) - Method in interface io.servicetalk.transport.api.ServerSecurityConfigurator
-
- trustManager(TrustManagerFactory) - Method in interface io.servicetalk.transport.api.ServerSecurityConfigurator
-
- trustManager(Supplier<InputStream>) - Method in class io.servicetalk.transport.netty.internal.ClientSecurityConfig
-
Trusted certificates for verifying the remote endpoint's certificate.
- trustManager(TrustManagerFactory) - Method in class io.servicetalk.transport.netty.internal.ClientSecurityConfig
-
Trust manager for verifying the remote endpoint's certificate.
- trustManager(Supplier<InputStream>) - Method in class io.servicetalk.transport.netty.internal.ServerSecurityConfig
-
Trusted certificates for verifying the remote endpoint's certificate.
- trustManager(TrustManagerFactory) - Method in class io.servicetalk.transport.netty.internal.ServerSecurityConfig
-
Trust manager for verifying the remote endpoint's certificate.
- tryAcquireLock(AtomicIntegerFieldUpdater<T>, T) - Static method in class io.servicetalk.concurrent.internal.ConcurrentUtils
-
- tryAcquireReentrantLock(AtomicLongFieldUpdater<T>, T) - Static method in class io.servicetalk.concurrent.internal.ConcurrentUtils
-
- tryConsume(ProcessorSignalsConsumer<T>) - Method in interface io.servicetalk.concurrent.api.PublisherProcessorSignalsHolder
-
Try to consume the next item stored in this holder.
- tryConsumeTerminal(ProcessorSignalsConsumer<T>) - Method in interface io.servicetalk.concurrent.api.PublisherProcessorSignalsHolder
-
- tryEnsureWritable(int, boolean) - Method in interface io.servicetalk.buffer.api.Buffer
-
Tries to make sure the number of
writable bytes
is equal to or greater than the specified value.
- tryRequest() - Method in interface io.servicetalk.client.api.internal.RequestConcurrencyController
-
- tryReserve() - Method in interface io.servicetalk.client.api.internal.ReservableRequestConcurrencyController
-
- trySetTerminal(TerminalNotification, boolean, AtomicReferenceFieldUpdater<R, TerminalNotification>, R) - Static method in class io.servicetalk.concurrent.internal.SubscriberUtils
-
There are some scenarios where a completion
TerminalNotification
can be overridden with an error if
errors are produced asynchronously.
- trySplit() - Method in interface io.servicetalk.concurrent.BlockingSpliterator
-
- ttl() - Method in interface io.servicetalk.dns.discovery.netty.DnsServiceDiscovererObserver.ResolutionResult
-
Minimum Time To Live (TTL) of the resolved DNS records in seconds.
- type - Variable in class io.servicetalk.http.api.AbstractHttpRequesterFilterTest
-
- type() - Method in interface io.servicetalk.opentracing.inmemory.api.InMemoryReference
-
Returns the reference type.
- type() - Method in class io.servicetalk.serialization.api.TypeHolder
-
Returns the inferred generic type for this
TypeHolder
.
- TypeHolder<T> - Class in io.servicetalk.serialization.api
-
An abstract class to infer ParameterizedType
s for a child class.
- TypeHolder() - Constructor for class io.servicetalk.serialization.api.TypeHolder
-
Creates a new instance.
- validateCookies() - Method in class io.servicetalk.http.api.DefaultHttpHeadersFactory
-
- validateCookies() - Method in interface io.servicetalk.http.api.HttpHeadersFactory
-
Determine if a cookies should be validated during parsing into
HttpSetCookie
s.
- validateCookies() - Method in class io.servicetalk.http.netty.H2HeadersFactory
-
- validateHexBytes(T) - Static method in class io.servicetalk.opentracing.internal.HexUtils
-
Checks that the provided CharSequence
is a valid hex CharSequence
,
throwing an IllegalArgumentException
if it is not.
- validateRouteExecutionStrategyAnnotationIfPresent(Method, Class<?>, RouteExecutionStrategyFactory<? extends ExecutionStrategy>, Set<String>) - Static method in class io.servicetalk.router.utils.internal.RouteExecutionStrategyUtils
-
- value() - Method in enum io.servicetalk.grpc.api.GrpcStatusCode
-
Returns the integer code value.
- value() - Method in class io.servicetalk.http.api.DefaultHttpCookiePair
-
- value() - Method in class io.servicetalk.http.api.DefaultHttpSetCookie
-
- value() - Method in interface io.servicetalk.http.api.HttpCookiePair
-
- value(Predicate<HttpCookiePair>) - Method in interface io.servicetalk.http.router.predicate.dsl.CookieMatcher
-
Matches requests where one of the cookies with the specified name matches predicate
.
- valueOf(String) - Static method in enum io.servicetalk.client.api.internal.RequestConcurrencyController.Result
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.servicetalk.dns.discovery.netty.DnsResolverAddressTypes
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.servicetalk.grpc.api.GrpcMessageEncoding
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.servicetalk.grpc.api.GrpcStatusCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.servicetalk.http.api.AbstractHttpRequesterFilterTest.RequesterType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.servicetalk.http.api.AbstractHttpRequesterFilterTest.SecurityType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.servicetalk.http.api.AbstractHttpServiceFilterTest.SecurityType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.servicetalk.http.api.HttpResponseStatus.StatusClass
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.servicetalk.http.api.HttpSetCookie.SameSite
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest.RouterApi
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.servicetalk.http.router.jersey.ExecutionStrategyTest.TestExecutorStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.servicetalk.http.router.jersey.ExecutionStrategyTest.TestMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.servicetalk.opentracing.zipkin.publisher.reporter.Codec
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.servicetalk.opentracing.zipkin.publisher.reporter.LoggingReporter.LogLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.servicetalk.transport.api.SecurityConfigurator.SslProvider
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.servicetalk.transport.api.ServerSecurityConfigurator.ClientAuth
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.servicetalk.transport.netty.internal.CloseHandler.CloseEvent
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.servicetalk.transport.netty.internal.SplittingFlushStrategy.FlushBoundaryProvider.FlushBoundary
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum io.servicetalk.client.api.internal.RequestConcurrencyController.Result
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.servicetalk.dns.discovery.netty.DnsResolverAddressTypes
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.servicetalk.grpc.api.GrpcMessageEncoding
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.servicetalk.grpc.api.GrpcStatusCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.servicetalk.http.api.AbstractHttpRequesterFilterTest.RequesterType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.servicetalk.http.api.AbstractHttpRequesterFilterTest.SecurityType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.servicetalk.http.api.AbstractHttpServiceFilterTest.SecurityType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values(CharSequence) - Method in interface io.servicetalk.http.api.HttpHeaders
-
Returns all values for the header with the specified name.
- values() - Static method in enum io.servicetalk.http.api.HttpResponseStatus.StatusClass
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.servicetalk.http.api.HttpSetCookie.SameSite
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest.RouterApi
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.servicetalk.http.router.jersey.ExecutionStrategyTest.TestExecutorStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.servicetalk.http.router.jersey.ExecutionStrategyTest.TestMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values(Predicate<Iterator<? extends HttpCookiePair>>) - Method in interface io.servicetalk.http.router.predicate.dsl.CookieMatcher
-
Matches requests where the list of cookies for the specified name matches the predicate.
- values(Predicate<Iterator<? extends CharSequence>>) - Method in interface io.servicetalk.http.router.predicate.dsl.StringMultiValueMatcher
-
Matches requests where the list of values matches the predicate.
- values() - Static method in enum io.servicetalk.opentracing.zipkin.publisher.reporter.Codec
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.servicetalk.opentracing.zipkin.publisher.reporter.LoggingReporter.LogLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.servicetalk.transport.api.SecurityConfigurator.SslProvider
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.servicetalk.transport.api.ServerSecurityConfigurator.ClientAuth
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.servicetalk.transport.netty.internal.CloseHandler.CloseEvent
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.servicetalk.transport.netty.internal.SplittingFlushStrategy.FlushBoundaryProvider.FlushBoundary
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- valuesIterator(CharSequence) - Method in class io.servicetalk.http.api.EmptyHttpHeaders
-
- valuesIterator(CharSequence) - Method in interface io.servicetalk.http.api.HttpHeaders
-
Returns all values for the header with the specified name.
- VARIANT_ALSO_NEGOTIATES - Static variable in class io.servicetalk.http.api.HttpResponseStatus
-
506 Variant Also Negotiates
- variantAlsoNegotiates() - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponseFactory
-
- variantAlsoNegotiates() - Method in interface io.servicetalk.http.api.HttpResponseFactory
-
- variantAlsoNegotiates() - Method in interface io.servicetalk.http.api.StreamingHttpResponseFactory
-
- VARY - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"vary"
- VerificationTestUtils - Class in io.servicetalk.concurrent.api
-
- verifyApplied() - Method in class io.servicetalk.transport.netty.internal.MockFlushStrategy
-
- verifyCancelled() - Method in class io.servicetalk.concurrent.api.LegacyMockedCompletableListenerRule
-
Deprecated.
- verifyCancelled() - Method in class io.servicetalk.concurrent.api.LegacyTestCompletable
-
Deprecated.
- verifyCancelled() - Method in class io.servicetalk.concurrent.api.LegacyTestSingle
-
Deprecated.
- verifyCompletion() - Method in class io.servicetalk.concurrent.api.LegacyMockedCompletableListenerRule
-
Deprecated.
- verifyFailure(Throwable) - Method in class io.servicetalk.concurrent.api.LegacyMockedCompletableListenerRule
-
Deprecated.
- verifyFailure(ArgumentCaptor<Throwable>) - Method in class io.servicetalk.concurrent.api.LegacyMockedCompletableListenerRule
-
Deprecated.
- verifyFailure(Class<? extends Throwable>) - Method in class io.servicetalk.concurrent.api.LegacyMockedCompletableListenerRule
-
Deprecated.
- verifyFailure(Throwable) - Method in class io.servicetalk.concurrent.api.LegacyMockedSingleListenerRule
-
Deprecated.
- verifyFailure(ArgumentCaptor<Throwable>) - Method in class io.servicetalk.concurrent.api.LegacyMockedSingleListenerRule
-
Deprecated.
- verifyFailure(Class<? extends Throwable>) - Method in class io.servicetalk.concurrent.api.LegacyMockedSingleListenerRule
-
Deprecated.
- verifyItemWritten(int) - Method in class io.servicetalk.transport.netty.internal.MockFlushStrategy
-
- verifyListenCalled() - Method in class io.servicetalk.concurrent.api.LegacyTestCompletable
-
Deprecated.
- verifyListenCalled() - Method in class io.servicetalk.concurrent.api.LegacyTestSingle
-
Deprecated.
- verifyListenCalled(int) - Method in class io.servicetalk.concurrent.api.LegacyTestSingle
-
Deprecated.
- verifyListenNotCalled() - Method in class io.servicetalk.concurrent.api.LegacyTestCompletable
-
Deprecated.
- verifyListenNotCalled() - Method in class io.servicetalk.concurrent.api.LegacyTestSingle
-
Deprecated.
- verifyNoEmissions() - Method in class io.servicetalk.concurrent.api.LegacyMockedCompletableListenerRule
-
Deprecated.
- verifyNoEmissions() - Method in class io.servicetalk.concurrent.api.LegacyMockedSingleListenerRule
-
Deprecated.
- verifyNoMoreInteractions() - Method in class io.servicetalk.transport.netty.internal.MockFlushStrategy
-
- verifyNotCancelled() - Method in class io.servicetalk.concurrent.api.LegacyTestCompletable
-
Deprecated.
- verifyNotCancelled() - Method in class io.servicetalk.concurrent.api.LegacyTestSingle
-
Deprecated.
- verifyOriginalAndSuppressedCauses(Throwable, Throwable, Throwable) - Static method in class io.servicetalk.concurrent.api.VerificationTestUtils
-
- verifySuccess(T) - Method in class io.servicetalk.concurrent.api.LegacyMockedSingleListenerRule
-
Deprecated.
- verifySuccessAndReturn(Class<T>) - Method in class io.servicetalk.concurrent.api.LegacyMockedSingleListenerRule
-
Deprecated.
- verifySuppressed(Throwable, Throwable) - Static method in class io.servicetalk.concurrent.api.VerificationTestUtils
-
- verifySuppressedFailure(Throwable, Throwable) - Method in class io.servicetalk.concurrent.api.LegacyMockedCompletableListenerRule
-
Deprecated.
- verifySuppressedFailure(Class<? extends Throwable>, Class<? extends Throwable>) - Method in class io.servicetalk.concurrent.api.LegacyMockedCompletableListenerRule
-
Deprecated.
- verifySuppressedFailure(Throwable) - Method in class io.servicetalk.concurrent.api.LegacyMockedCompletableListenerRule
-
Deprecated.
- verifySuppressedFailure(Throwable, Throwable) - Method in class io.servicetalk.concurrent.api.LegacyMockedSingleListenerRule
-
Deprecated.
- verifySuppressedFailure(Throwable) - Method in class io.servicetalk.concurrent.api.LegacyMockedSingleListenerRule
-
Deprecated.
- verifyWriteCancelled() - Method in class io.servicetalk.transport.netty.internal.MockFlushStrategy
-
- verifyWriteStarted() - Method in class io.servicetalk.transport.netty.internal.MockFlushStrategy
-
- verifyWriteTerminated() - Method in class io.servicetalk.transport.netty.internal.MockFlushStrategy
-
- version(HttpProtocolVersion) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpRequest
-
- version(HttpProtocolVersion) - Method in interface io.servicetalk.http.api.BlockingStreamingHttpResponse
-
- version(HttpProtocolVersion) - Method in class io.servicetalk.http.api.BlockingStreamingHttpServerResponse
-
- version() - Method in interface io.servicetalk.http.api.HttpMetaData
-
- version(HttpProtocolVersion) - Method in interface io.servicetalk.http.api.HttpMetaData
-
- version(HttpProtocolVersion) - Method in interface io.servicetalk.http.api.HttpRequest
-
- version(HttpProtocolVersion) - Method in interface io.servicetalk.http.api.HttpRequestMetaData
-
- version(HttpProtocolVersion) - Method in interface io.servicetalk.http.api.HttpResponse
-
- version(HttpProtocolVersion) - Method in interface io.servicetalk.http.api.HttpResponseMetaData
-
- version(HttpProtocolVersion) - Method in interface io.servicetalk.http.api.StreamingHttpRequest
-
- version(HttpProtocolVersion) - Method in interface io.servicetalk.http.api.StreamingHttpResponse
-
- VIA - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"via"
- WARNING - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"warning"
- WEBSOCKET - Static variable in class io.servicetalk.http.api.HttpHeaderValues
-
"websocket"
- WEBSOCKET_LOCATION - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"websocket-location"
- WEBSOCKET_ORIGIN - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"websocket-origin"
- WEBSOCKET_PROTOCOL - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"websocket-protocol"
- when(Predicate<StreamingHttpRequest>) - Method in interface io.servicetalk.http.router.predicate.dsl.RouteStarter
-
- when(BiPredicate<ConnectionContext, StreamingHttpRequest>) - Method in interface io.servicetalk.http.router.predicate.dsl.RouteStarter
-
- when(Predicate<StreamingHttpRequest>) - Method in class io.servicetalk.http.router.predicate.HttpPredicateRouterBuilder
-
- when(BiPredicate<ConnectionContext, StreamingHttpRequest>) - Method in class io.servicetalk.http.router.predicate.HttpPredicateRouterBuilder
-
- whenCancel(Runnable) - Method in class io.servicetalk.concurrent.api.Completable
-
- whenCancel(Runnable) - Method in class io.servicetalk.concurrent.api.Publisher
-
- whenCancel(Runnable) - Method in class io.servicetalk.concurrent.api.Single
-
- whenCookie(String) - Method in interface io.servicetalk.http.router.predicate.dsl.RouteStarter
-
- whenCookie(String) - Method in class io.servicetalk.http.router.predicate.HttpPredicateRouterBuilder
-
- whenFinally(Runnable) - Method in class io.servicetalk.concurrent.api.Completable
-
- whenFinally(TerminalSignalConsumer) - Method in class io.servicetalk.concurrent.api.Completable
-
- whenFinally(Runnable) - Method in class io.servicetalk.concurrent.api.Publisher
-
- whenFinally(TerminalSignalConsumer) - Method in class io.servicetalk.concurrent.api.Publisher
-
- whenFinally(Runnable) - Method in class io.servicetalk.concurrent.api.Single
-
- whenFinally(TerminalSignalConsumer) - Method in class io.servicetalk.concurrent.api.Single
-
- whenFinally(SingleTerminalSignalConsumer<? super T>) - Method in class io.servicetalk.concurrent.api.Single
-
- whenHeader(CharSequence) - Method in interface io.servicetalk.http.router.predicate.dsl.RouteStarter
-
- whenHeader(CharSequence) - Method in class io.servicetalk.http.router.predicate.HttpPredicateRouterBuilder
-
- whenIdleFor(Duration) - Static method in class io.servicetalk.http.netty.H2KeepAlivePolicies
-
- whenIdleFor(Duration, Duration) - Static method in class io.servicetalk.http.netty.H2KeepAlivePolicies
-
- whenIsNotSsl() - Method in interface io.servicetalk.http.router.predicate.dsl.RouteStarter
-
Begin a route that matches requests that are not over SSL/TLS.
- whenIsNotSsl() - Method in class io.servicetalk.http.router.predicate.HttpPredicateRouterBuilder
-
- whenIsSsl() - Method in interface io.servicetalk.http.router.predicate.dsl.RouteStarter
-
Begin a route that matches requests that are over SSL/TLS.
- whenIsSsl() - Method in class io.servicetalk.http.router.predicate.HttpPredicateRouterBuilder
-
- whenMethod(HttpRequestMethod) - Method in interface io.servicetalk.http.router.predicate.dsl.RouteStarter
-
- whenMethod(HttpRequestMethod) - Method in class io.servicetalk.http.router.predicate.HttpPredicateRouterBuilder
-
- whenMethodIsOneOf(HttpRequestMethod...) - Method in interface io.servicetalk.http.router.predicate.dsl.RouteStarter
-
Begin a route that matches requests where the
HttpRequestMethod
is one of the
methods
.
- whenMethodIsOneOf(HttpRequestMethod...) - Method in class io.servicetalk.http.router.predicate.HttpPredicateRouterBuilder
-
- whenOnComplete(Runnable) - Method in class io.servicetalk.concurrent.api.Completable
-
- whenOnComplete(Runnable) - Method in class io.servicetalk.concurrent.api.Publisher
-
- whenOnError(Consumer<Throwable>) - Method in class io.servicetalk.concurrent.api.Completable
-
- whenOnError(Consumer<Throwable>) - Method in class io.servicetalk.concurrent.api.Publisher
-
- whenOnError(Consumer<Throwable>) - Method in class io.servicetalk.concurrent.api.Single
-
- whenOnNext(Consumer<? super T>) - Method in class io.servicetalk.concurrent.api.Publisher
-
- whenOnSubscribe(Consumer<Cancellable>) - Method in class io.servicetalk.concurrent.api.Completable
-
- whenOnSubscribe(Consumer<? super PublisherSource.Subscription>) - Method in class io.servicetalk.concurrent.api.Publisher
-
- whenOnSubscribe(Consumer<Cancellable>) - Method in class io.servicetalk.concurrent.api.Single
-
- whenOnSuccess(Consumer<? super T>) - Method in class io.servicetalk.concurrent.api.Single
-
- whenPathEquals(String) - Method in interface io.servicetalk.http.router.predicate.dsl.RouteStarter
-
Begin a route that matches requests where the path is equal to path
.
- whenPathEquals(String) - Method in class io.servicetalk.http.router.predicate.HttpPredicateRouterBuilder
-
- whenPathIsOneOf(String...) - Method in interface io.servicetalk.http.router.predicate.dsl.RouteStarter
-
Begin a route that matches requests where the path is equal to any of the specified path
s.
- whenPathIsOneOf(String...) - Method in class io.servicetalk.http.router.predicate.HttpPredicateRouterBuilder
-
- whenPathMatches(String) - Method in interface io.servicetalk.http.router.predicate.dsl.RouteStarter
-
Begin a route that matches requests where the path matches the regex pathRegex
.
- whenPathMatches(Pattern) - Method in interface io.servicetalk.http.router.predicate.dsl.RouteStarter
-
Begin a route that matches requests where the path matches the regex pathRegex
.
- whenPathMatches(String) - Method in class io.servicetalk.http.router.predicate.HttpPredicateRouterBuilder
-
- whenPathMatches(Pattern) - Method in class io.servicetalk.http.router.predicate.HttpPredicateRouterBuilder
-
- whenPathStartsWith(String) - Method in interface io.servicetalk.http.router.predicate.dsl.RouteStarter
-
Begin a route that matches requests where the path starts with pathPrefix
.
- whenPathStartsWith(String) - Method in class io.servicetalk.http.router.predicate.HttpPredicateRouterBuilder
-
- whenQueryParam(String) - Method in interface io.servicetalk.http.router.predicate.dsl.RouteStarter
-
- whenQueryParam(String) - Method in class io.servicetalk.http.router.predicate.HttpPredicateRouterBuilder
-
- whenRequest(LongConsumer) - Method in class io.servicetalk.concurrent.api.Publisher
-
- whenSubscriber(Supplier<? extends CompletableSource.Subscriber>) - Method in class io.servicetalk.concurrent.api.Completable
-
- whenSubscriber(Supplier<? extends PublisherSource.Subscriber<? super T>>) - Method in class io.servicetalk.concurrent.api.Publisher
-
- whenSubscriber(Supplier<? extends SingleSource.Subscriber<? super T>>) - Method in class io.servicetalk.concurrent.api.Single
-
- whenSubscription(Supplier<? extends PublisherSource.Subscription>) - Method in class io.servicetalk.concurrent.api.Publisher
-
- WireLoggingInitializer - Class in io.servicetalk.transport.netty.internal
-
- WireLoggingInitializer(String) - Constructor for class io.servicetalk.transport.netty.internal.WireLoggingInitializer
-
Create an instance that logs at trace level.
- with(LimitingConnectionFactoryFilter.ConnectionLimiter<A, C>) - Static method in class io.servicetalk.client.api.LimitingConnectionFactoryFilter
-
- withContext() - Method in interface io.servicetalk.http.api.AbstractHttpRequesterFilterTest.RequestHandler
-
- withExecutor(Supplier<Executor>) - Static method in class io.servicetalk.concurrent.api.ExecutorRule
-
- withHeader(StreamingHttpRequest, String, String) - Method in class io.servicetalk.http.router.jersey.AbstractNonParameterizedJerseyStreamingHttpServiceTest
-
- withMax(int) - Static method in class io.servicetalk.client.api.LimitingConnectionFactoryFilter
-
Create a new
ConnectionFactory
that only creates a maximum of
maxConnections
active connections.
- withMaxTagSize(int) - Method in class io.servicetalk.opentracing.inmemory.DefaultInMemoryTracer.Builder
-
Sets the maximum number of tags.
- withNamePrefix(String) - Static method in class io.servicetalk.concurrent.api.ExecutorRule
-
Create an
ExecutorRule
with a default executor, configured to prefix thread names
with
namePrefix
.
- withoutActiveStreams(boolean) - Method in class io.servicetalk.http.netty.H2KeepAlivePolicies.KeepAlivePolicyBuilder
-
Allow/disallow sending
pings even
when no streams are
active.
- withoutActiveStreams() - Method in interface io.servicetalk.http.netty.H2ProtocolConfig.KeepAlivePolicy
-
Whether this policy allows to send
pings
even if there are no streams active on the connection.
- withSampler(Predicate<String>) - Method in class io.servicetalk.opentracing.inmemory.DefaultInMemoryTracer.Builder
-
Sets the sampler.
- withSampler(BiFunction<String, Boolean, Boolean>) - Method in class io.servicetalk.opentracing.inmemory.DefaultInMemoryTracer.Builder
-
Sets the sampler.
- withStartTimestamp(long) - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpanBuilder
-
- withTag(String, String) - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpanBuilder
-
- withTag(String, boolean) - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpanBuilder
-
- withTag(String, Number) - Method in interface io.servicetalk.opentracing.inmemory.api.InMemorySpanBuilder
-
- withTestExecutor() - Static method in class io.servicetalk.concurrent.api.ExecutorRule
-
- wrap(byte[]) - Method in interface io.servicetalk.buffer.api.BufferAllocator
-
Create a new
Buffer
that wraps the given byte array.
- wrap(byte[], int, int) - Method in interface io.servicetalk.buffer.api.BufferAllocator
-
Create a new
Buffer
that wraps the given byte array.
- wrap(ByteBuffer) - Method in interface io.servicetalk.buffer.api.BufferAllocator
-
Create a new
Buffer
that wraps the given
ByteBuffer
.
- wrap(PublisherSource.Subscription) - Static method in class io.servicetalk.concurrent.internal.ConcurrentSubscription
-
- wrap(GrpcRoutes.BlockingRequestStreamingRoute<Req, Resp>, GracefulAutoCloseable) - Static method in interface io.servicetalk.grpc.api.GrpcRoutes.BlockingRequestStreamingRoute
-
- wrap(GrpcRoutes.BlockingResponseStreamingRoute<Req, Resp>, GracefulAutoCloseable) - Static method in interface io.servicetalk.grpc.api.GrpcRoutes.BlockingResponseStreamingRoute
-
- wrap(GrpcRoutes.BlockingRoute<Req, Resp>, GracefulAutoCloseable) - Static method in interface io.servicetalk.grpc.api.GrpcRoutes.BlockingRoute
-
- wrap(GrpcRoutes.BlockingStreamingRoute<Req, Resp>, GracefulAutoCloseable) - Static method in interface io.servicetalk.grpc.api.GrpcRoutes.BlockingStreamingRoute
-
- wrap(GrpcRoutes.RequestStreamingRoute<Req, Resp>, AsyncCloseable) - Static method in interface io.servicetalk.grpc.api.GrpcRoutes.RequestStreamingRoute
-
- wrap(GrpcRoutes.ResponseStreamingRoute<Req, Resp>, AsyncCloseable) - Static method in interface io.servicetalk.grpc.api.GrpcRoutes.ResponseStreamingRoute
-
- wrap(GrpcRoutes.Route<Req, Resp>, AsyncCloseable) - Static method in interface io.servicetalk.grpc.api.GrpcRoutes.Route
-
- wrap(GrpcRoutes.StreamingRoute<Req, Resp>, AsyncCloseable) - Static method in interface io.servicetalk.grpc.api.GrpcRoutes.StreamingRoute
-
- wrap(NettyServerContext, AsyncCloseable) - Static method in class io.servicetalk.transport.netty.internal.NettyServerContext
-
- wrap(Channel, ListenableAsyncCloseable, AsyncCloseable, ExecutionContext) - Static method in class io.servicetalk.transport.netty.internal.NettyServerContext
-
- wrapBiConsume(BiConsumer<T, U>) - Static method in class io.servicetalk.concurrent.api.AsyncContext
-
Wrap a
BiFunction
to ensure it is able to track
AsyncContext
correctly.
- wrapBiFunction(BiFunction<T, U, V>) - Static method in class io.servicetalk.concurrent.api.AsyncContext
-
Wrap a
BiFunction
to ensure it is able to track
AsyncContext
correctly.
- wrapConsumer(Consumer<T>) - Static method in class io.servicetalk.concurrent.api.AsyncContext
-
Wrap a
Consumer
to ensure it is able to track
AsyncContext
correctly.
- wrapExecutor(Executor) - Static method in class io.servicetalk.concurrent.api.AsyncContext
-
- wrapFunction(Function<T, U>) - Static method in class io.servicetalk.concurrent.api.AsyncContext
-
Wrap a
Function
to ensure it is able to track
AsyncContext
correctly.
- wrapJdkExecutor(Executor) - Static method in class io.servicetalk.concurrent.api.AsyncContext
-
Wrap an
Executor
to ensure it is able to track
AsyncContext
correctly.
- wrapJdkExecutorService(ExecutorService) - Static method in class io.servicetalk.concurrent.api.AsyncContext
-
Wrap an
ExecutorService
to ensure it is able to track
AsyncContext
correctly.
- wrapJdkScheduledExecutorService(ScheduledExecutorService) - Static method in class io.servicetalk.concurrent.api.AsyncContext
-
Wrap a
ScheduledExecutorService
to ensure it is able to track
AsyncContext
correctly.
- wrapRunnable(Runnable) - Static method in class io.servicetalk.concurrent.api.AsyncContext
-
Wrap a
Runnable
to ensure it is able to track
AsyncContext
correctly.
- writableBytes() - Method in interface io.servicetalk.buffer.api.Buffer
-
Returns the number of writable bytes which is equal to
(this.capacity - this.writerIndex)
.
- writableBytes() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- write(int) - Method in class io.servicetalk.concurrent.api.internal.ConnectableBufferOutputStream
-
- write(byte[]) - Method in class io.servicetalk.concurrent.api.internal.ConnectableBufferOutputStream
-
- write(byte[], int, int) - Method in class io.servicetalk.concurrent.api.internal.ConnectableBufferOutputStream
-
- write(T) - Method in class io.servicetalk.concurrent.api.internal.ConnectablePayloadWriter
-
- write(T) - Method in interface io.servicetalk.oio.api.PayloadWriter
-
Write an object of type T
.
- write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.servicetalk.transport.netty.internal.BufferHandler
-
- write(Publisher<Write>) - Method in class io.servicetalk.transport.netty.internal.DefaultNettyConnection
-
- write(Publisher<Write>, Supplier<FlushStrategy>, Supplier<WriteDemandEstimator>) - Method in class io.servicetalk.transport.netty.internal.DefaultNettyConnection
-
- write(Publisher<Write>) - Method in interface io.servicetalk.transport.netty.internal.NettyConnection
-
Writes all elements emitted by the passed
Publisher
on this connection.
- write(Publisher<Write>, Supplier<FlushStrategy>, Supplier<WriteDemandEstimator>) - Method in interface io.servicetalk.transport.netty.internal.NettyConnection
-
Writes all elements emitted by the passed
Publisher
on this connection.
- WRITE_BUFFER_THRESHOLD - Static variable in class io.servicetalk.transport.api.ServiceTalkSocketOptions
-
The threshold after which the the Endpoint is not writable anymore.
- writeAscii(CharSequence) - Method in interface io.servicetalk.buffer.api.Buffer
-
Encode a
CharSequence
in
ASCII and write it
to this buffer starting at
writerIndex
and increases the
writerIndex
by the
number of the transferred bytes.
- writeAscii(CharSequence) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeAscii(CharSequence) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeBoolean(boolean) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified boolean at the current writerIndex
and increases the writerIndex
by 1
in this buffer.
- writeBoolean(boolean) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeBoolean(boolean) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeByte(int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified byte at the current writerIndex
and increases the writerIndex
by 1
in this buffer.
- writeByte(int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeByte(int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeBytes(Buffer) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers the specified source buffer's data to this buffer starting at
the current writerIndex
until the source buffer becomes
unreadable, and increases the writerIndex
by the number of
the transferred bytes.
- writeBytes(Buffer, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers the specified source buffer's data to this buffer starting at
the current writerIndex
and increases the writerIndex
by the number of the transferred bytes (= length
).
- writeBytes(Buffer, int, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers the specified source buffer's data to this buffer starting at
the current writerIndex
and increases the writerIndex
by the number of the transferred bytes (= length
).
- writeBytes(byte[]) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers the specified source array's data to this buffer starting at
the current writerIndex
and increases the writerIndex
by the number of the transferred bytes (= src.length
).
- writeBytes(byte[], int, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers the specified source array's data to this buffer starting at
the current writerIndex
and increases the writerIndex
by the number of the transferred bytes (= length
).
- writeBytes(ByteBuffer) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers the specified source buffer's data to this buffer starting at
the current writerIndex
until the source buffer's position
reaches its limit, and increases the writerIndex
by the
number of the transferred bytes.
- writeBytes(InputStream, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers ta fixed amount from the specified source InputStream
's data to this buffer starting at
the current writerIndex
until length
bytes have been read, the end of stream
is reached, or an exception is thrown.
- writeBytes(Buffer) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeBytes(Buffer, int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeBytes(Buffer, int, int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeBytes(byte[]) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeBytes(byte[], int, int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeBytes(ByteBuffer) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeBytes(Buffer) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeBytes(Buffer, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeBytes(Buffer, int, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeBytes(byte[]) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeBytes(byte[], int, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeBytes(ByteBuffer) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeBytes(InputStream, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeBytesUntilEndStream(InputStream, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Transfers all the specified source InputStream
's data to this buffer starting at
the current writerIndex
until the end of stream is reached or an exception is thrown.
- writeBytesUntilEndStream(InputStream, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeCancelled() - Method in interface io.servicetalk.transport.netty.internal.FlushStrategy.WriteEventsListener
-
- writeCancelled() - Method in class io.servicetalk.transport.netty.internal.NoopWriteEventsListener
-
- writeChar(int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 2-byte UTF-16 character at the current
writerIndex
and increases the writerIndex
by 2
in this buffer.
- writeChar(int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeChar(int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- WriteDemandEstimator - Interface in io.servicetalk.transport.netty.internal
-
Provides an estimate for the value of n
for calls to PublisherSource.Subscription#request(long)
per
PublisherSource.Subscription
.
- WriteDemandEstimators - Class in io.servicetalk.transport.netty.internal
-
- writeDouble(double) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 64-bit floating point number at the current
writerIndex
and increases the writerIndex
by 8
in this buffer.
- writeDouble(double) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeDouble(double) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeFloat(float) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 32-bit floating point number at the current
writerIndex
and increases the writerIndex
by 4
in this buffer.
- writeFloat(float) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeFloat(float) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeInt(int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 32-bit integer at the current writerIndex
and increases the writerIndex
by 4
in this buffer.
- writeInt(int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeInt(int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeIntLE(int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 32-bit integer at the current writerIndex
in the Little Endian Byte Order and increases the writerIndex
by 4
in this buffer.
- writeIntLE(int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeIntLE(int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeLong(long) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 64-bit long integer at the current
writerIndex
and increases the writerIndex
by 8
in this buffer.
- writeLong(long) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeLong(long) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeLongLE(long) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 64-bit long integer at the current
writerIndex
in the Little Endian Byte Order and
increases the writerIndex
by 8
in this buffer.
- writeLongLE(long) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeLongLE(long) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeMedium(int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 24-bit medium integer at the current
writerIndex
and increases the writerIndex
by 3
in this buffer.
- writeMedium(int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeMedium(int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeMediumLE(int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 24-bit medium integer at the current
writerIndex
in the Little Endian Byte Order and
increases the writerIndex
by 3
in this
buffer.
- writeMediumLE(int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeMediumLE(int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writerIndex() - Method in interface io.servicetalk.buffer.api.Buffer
-
Returns the writerIndex
of this buffer.
- writerIndex(int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the writerIndex
of this buffer.
- writerIndex(int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writerIndex() - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writerIndex(int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeShort(int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 16-bit short integer at the current
writerIndex
and increases the writerIndex
by 2
in this buffer.
- writeShort(int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeShort(int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeShortLE(int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Sets the specified 16-bit short integer in the Little Endian Byte
Order at the current writerIndex
and increases the
writerIndex
by 2
in this buffer.
- writeShortLE(int) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeShortLE(int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeStarted() - Method in interface io.servicetalk.transport.netty.internal.FlushStrategy.WriteEventsListener
-
- writeStarted() - Method in class io.servicetalk.transport.netty.internal.NoopWriteEventsListener
-
- writeTerminated() - Method in interface io.servicetalk.transport.netty.internal.FlushStrategy.WriteEventsListener
-
- writeTerminated() - Method in class io.servicetalk.transport.netty.internal.NoopWriteEventsListener
-
- writeTo(Buffer) - Method in class io.servicetalk.http.api.HttpProtocolVersion
-
- writeTo(Buffer) - Method in class io.servicetalk.http.api.HttpRequestMethod
-
- writeTo(Buffer) - Method in class io.servicetalk.http.api.HttpResponseStatus
-
- writeUtf8(CharSequence) - Method in interface io.servicetalk.buffer.api.Buffer
-
Encode a
CharSequence
in
UTF-8 and write it
to this buffer starting at
writerIndex
and increases the
writerIndex
by the
number of the transferred bytes.
- writeUtf8(CharSequence, int) - Method in interface io.servicetalk.buffer.api.Buffer
-
Encode a
CharSequence
in
UTF-8 and write it
to this buffer starting at
writerIndex
and increases the
writerIndex
by the
number of the transferred bytes.
- writeUtf8(CharSequence) - Method in interface io.servicetalk.buffer.api.CompositeBuffer
-
- writeUtf8(CharSequence) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- writeUtf8(CharSequence, int) - Method in class io.servicetalk.buffer.api.EmptyBuffer
-
- WWW_AUTHENTICATE - Static variable in class io.servicetalk.http.api.HttpHeaderNames
-
"www-authenticate"