Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- abort(boolean) - Method in class com.github.mizosoft.methanol.internal.flow.AbstractQueueSubscription
- abort(boolean) - Method in class com.github.mizosoft.methanol.internal.flow.AbstractSubscription
-
Releases resources held by this subscription.
- abort(boolean) - Method in class com.github.mizosoft.methanol.testing.SubmittableSubscription
- abortCount() - Method in class com.github.mizosoft.methanol.testing.SubmittableSubscription
- AbstractBodyAdapter - Class in com.github.mizosoft.methanol.adapter
-
An abstract
BodyAdapter
that implementsBodyAdapter.isCompatibleWith(MediaType)
by allowing subclasses to specify a set ofMediaTypes
the adapter is compatible with. - AbstractBodyAdapter(MediaType...) - Constructor for class com.github.mizosoft.methanol.adapter.AbstractBodyAdapter
-
Creates an
AbstractBodyAdapter
compatible with the given media types. - AbstractBodyAdapter.BaseDecoder - Interface in com.github.mizosoft.methanol.adapter
-
This interface abstracts the more-capable
AbstractBodyAdapter.BaseDecoder.toObject(TypeRef, Hints)
method and adds a default implementation forAbstractBodyAdapter.BaseDecoder.toObject(TypeRef, MediaType)
that forwards to the former. - AbstractBodyAdapter.BaseEncoder - Interface in com.github.mizosoft.methanol.adapter
-
This interface abstracts the more-capable
AbstractBodyAdapter.BaseEncoder.toBody(Object, TypeRef, Hints)
method and adds a default implementation forAbstractBodyAdapter.BaseEncoder.toBody(Object, MediaType)
that forwards to the former. - AbstractPollableSubscription<T> - Class in com.github.mizosoft.methanol.internal.flow
-
A subscription that emits items from a pollable source.
- AbstractPollableSubscription(Flow.Subscriber<? super T>, Executor) - Constructor for class com.github.mizosoft.methanol.internal.flow.AbstractPollableSubscription
- AbstractQueueSubscription<T> - Class in com.github.mizosoft.methanol.internal.flow
-
A subscription that emits items from a queue and completes downstream as soon as a sentinel value is observed.
- AbstractQueueSubscription(Flow.Subscriber<? super T>, Executor) - Constructor for class com.github.mizosoft.methanol.internal.flow.AbstractQueueSubscription
- AbstractQueueSubscription(Flow.Subscriber<? super T>, Executor, Queue<T>) - Constructor for class com.github.mizosoft.methanol.internal.flow.AbstractQueueSubscription
- AbstractQueueSubscription(Flow.Subscriber<? super T>, Executor, Queue<T>, T) - Constructor for class com.github.mizosoft.methanol.internal.flow.AbstractQueueSubscription
- AbstractSubscription<T> - Class in com.github.mizosoft.methanol.internal.flow
-
An abstract
Flow.Subscription
that implements most of the machinery for execution and backpressure control. - AbstractSubscription(Flow.Subscriber<? super T>, Executor) - Constructor for class com.github.mizosoft.methanol.internal.flow.AbstractSubscription
- accept(T) - Method in interface com.github.mizosoft.methanol.function.ThrowingConsumer
- accept(T, U) - Method in interface com.github.mizosoft.methanol.internal.function.ThrowingBiConsumer
- adapterCodec() - Method in class com.github.mizosoft.methanol.Methanol
- adapterCodec() - Method in class com.github.mizosoft.methanol.MutableRequest
-
Returns the
AdapterCodec
to be used for resolving this request's payload. - adapterCodec(AdapterCodec) - Method in class com.github.mizosoft.methanol.Methanol.BaseBuilder
-
Specifies the
AdapterCodec
with which request and response payloads are mapped. - adapterCodec(AdapterCodec) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Set's the
AdapterCodec
to be used for resolving this request's payload. - AdapterCodec - Class in com.github.mizosoft.methanol
-
A group of
adapters
(encoders
invalid input: '&'decoders
), typically targeting different mapping schemes, that facilitates creating correspondingHttpRequest.BodyPublisher
,HttpResponse.BodyHandler
andHttpResponse.BodySubscriber
implementations. - AdapterCodec.Builder - Class in com.github.mizosoft.methanol
-
A builder of
AdapterCodec
instances. - add(String, String) - Method in class com.github.mizosoft.methanol.internal.extensions.HeadersBuilder
- add(T) - Method in class com.github.mizosoft.methanol.testing.CloseableCopyOnWriteList
- addAll(HeadersBuilder) - Method in class com.github.mizosoft.methanol.internal.extensions.HeadersBuilder
- addAll(String...) - Method in class com.github.mizosoft.methanol.internal.extensions.HeadersBuilder
- addAll(HttpHeaders) - Method in class com.github.mizosoft.methanol.internal.extensions.HeadersBuilder
- addAllLenient(HttpHeaders) - Method in class com.github.mizosoft.methanol.internal.extensions.HeadersBuilder
- addComment(int) - Method in class com.github.mizosoft.methanol.testing.MockGzipStream.Builder
- addExtraField(int) - Method in class com.github.mizosoft.methanol.testing.MockGzipStream.Builder
- addFileName(int) - Method in class com.github.mizosoft.methanol.testing.MockGzipStream.Builder
- addHeaderChecksum() - Method in class com.github.mizosoft.methanol.testing.MockGzipStream.Builder
- addLenient(String, String) - Method in class com.github.mizosoft.methanol.internal.extensions.HeadersBuilder
- advance(Duration) - Method in class com.github.mizosoft.methanol.testing.MockClock
- advanceSeconds(long) - Method in class com.github.mizosoft.methanol.testing.MockClock
- afterAll(ExtensionContext) - Method in class com.github.mizosoft.methanol.testing.MockWebServerExtension
- afterEach(ExtensionContext) - Method in class com.github.mizosoft.methanol.testing.MockWebServerExtension
- afterEach(ExtensionContext) - Method in class com.github.mizosoft.methanol.testing.store.StoreExtension
- AggregateException - Exception Class in com.github.mizosoft.methanol.testing
- AggregateException(String, Iterable<? extends Throwable>) - Constructor for exception class com.github.mizosoft.methanol.testing.AggregateException
- allMatch(CharSequence) - Method in interface com.github.mizosoft.methanol.internal.text.CharMatcher
- ANY - Static variable in class com.github.mizosoft.methanol.MediaType
-
*
/*
- anyMaxStale() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns whether the
max-stale
directive is present but has no value, which indicates that a response with any staleness is acceptable. - anyMaxStale() - Method in class com.github.mizosoft.methanol.CacheControl.Builder
-
Sets the
max-stale
directive to accept any stale response. - anyOf(String) - Static method in interface com.github.mizosoft.methanol.internal.text.CharMatcher
- APPLICATION_ANY - Static variable in class com.github.mizosoft.methanol.MediaType
-
application
/*
- APPLICATION_FORM_URLENCODED - Static variable in class com.github.mizosoft.methanol.MediaType
-
application/x-www-form-urlencoded
- APPLICATION_JSON - Static variable in class com.github.mizosoft.methanol.MediaType
-
application/json
- APPLICATION_OCTET_STREAM - Static variable in class com.github.mizosoft.methanol.MediaType
-
application/octet-stream
- APPLICATION_X_PROTOBUF - Static variable in class com.github.mizosoft.methanol.MediaType
-
application/x-protobuf
- APPLICATION_XHTML_XML - Static variable in class com.github.mizosoft.methanol.MediaType
-
application/xhtml+xml
- APPLICATION_XML - Static variable in class com.github.mizosoft.methanol.MediaType
-
application/xml
- apply(Consumer<? super B>) - Method in class com.github.mizosoft.methanol.Methanol.BaseBuilder
-
Calls the given consumer against this builder.
- apply(Consumer<? super MutableRequest>) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Calls the given consumer against this request.
- apply(T) - Method in interface com.github.mizosoft.methanol.internal.function.ThrowingFunction
- appVersion() - Method in class com.github.mizosoft.methanol.testing.store.StoreConfig
- appVersion() - Element in annotation interface com.github.mizosoft.methanol.testing.store.StoreSpec
- appVersion(int) - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore.Builder
- asBodyPublisher() - Method in class com.github.mizosoft.methanol.testing.verifiers.EncoderVerifier.ObjectConversionStep
- asHeadersAccumulator() - Method in class com.github.mizosoft.methanol.internal.extensions.HeadersBuilder
- assertEntryEquals(Store.Viewer, String, String) - Static method in class com.github.mizosoft.methanol.testing.store.StoreTesting
- assertEntryEquals(Store, String, String, String) - Static method in class com.github.mizosoft.methanol.testing.store.StoreTesting
- assertIsCacheAware() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- assertIsTracked() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- assertUnreadable(Store, String...) - Static method in class com.github.mizosoft.methanol.testing.store.StoreTesting
- ASYNC - Enum constant in enum class com.github.mizosoft.methanol.testing.store.StoreConfig.Execution
- AsyncBodyDecoder<T> - Class in com.github.mizosoft.methanol.decoder
-
An implementation of
BodyDecoder
that uses anAsyncDecoder
for decompression. - AsyncBodyDecoder(AsyncDecoder, HttpResponse.BodySubscriber<T>) - Constructor for class com.github.mizosoft.methanol.decoder.AsyncBodyDecoder
-
Creates an
AsyncBodyDecoder
in sync mode. - AsyncBodyDecoder(AsyncDecoder, HttpResponse.BodySubscriber<T>, Executor) - Constructor for class com.github.mizosoft.methanol.decoder.AsyncBodyDecoder
-
Creates an
AsyncBodyDecoder
that supplies downstream items in the given executor. - AsyncBodyDecoder(AsyncDecoder, HttpResponse.BodySubscriber<T>, Executor, int) - Constructor for class com.github.mizosoft.methanol.decoder.AsyncBodyDecoder
-
Creates an
AsyncBodyDecoder
that supplies downstream items in the given executor. - asyncDecoder() - Method in class com.github.mizosoft.methanol.decoder.AsyncBodyDecoder
-
Returns the underlying
AsyncDecoder
. - AsyncDecoder - Interface in com.github.mizosoft.methanol.decoder
-
An object that decompresses
ByteBuffer
chunks of a compressed stream in a non-blocking manner. - AsyncDecoder.ByteSink - Interface in com.github.mizosoft.methanol.decoder
-
A sink of bytes for writing the decompressed stream as
ByteBuffer
chunks. - AsyncDecoder.ByteSource - Interface in com.github.mizosoft.methanol.decoder
-
A source of bytes for reading the compressed stream as
ByteBuffer
chunks. - AsyncSubscriberAdapter<T,
S> - Class in com.github.mizosoft.methanol.internal.extensions -
Adapts a subscriber to a
BodySubscriber
where the body's completion need not be in accordance withonComplete
oronError
. - AsyncSubscriberAdapter(S, Function<? super S, ? extends CompletionStage<T>>) - Constructor for class com.github.mizosoft.methanol.internal.extensions.AsyncSubscriberAdapter
- attachMediaType(HttpRequest.BodyPublisher, MediaType) - Static method in class com.github.mizosoft.methanol.adapter.AbstractBodyAdapter
-
Converts the given publisher into a
MimeBodyPublisher
that has the given media type only if it is notnull
orhas a wildcard
, otherwise the given publisher is returned as-is. - authenticator() - Method in class com.github.mizosoft.methanol.Methanol
- authenticator() - Method in class com.github.mizosoft.methanol.testing.HttpClientStub
- authenticator() - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient
- authenticator(Authenticator) - Method in class com.github.mizosoft.methanol.Methanol.Builder
- autoAcceptEncoding() - Method in class com.github.mizosoft.methanol.Methanol
-
Returns this client's
auto Accept-Encoding
setting. - autoAcceptEncoding(boolean) - Method in class com.github.mizosoft.methanol.Methanol.BaseBuilder
-
If enabled, each request will have an
Accept-Encoding
header appended, the value of which is the set ofsupported encodings
. - autoAdvance(Duration) - Method in class com.github.mizosoft.methanol.testing.MockClock
- autoAdvanceClock() - Method in class com.github.mizosoft.methanol.testing.store.DiskStoreConfig
- autoAdvanceClock() - Element in annotation interface com.github.mizosoft.methanol.testing.store.StoreSpec
-
Whether
MockClock
should automatically advance itself by 1 second. - autoRequest(long) - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- awaitAbort() - Method in class com.github.mizosoft.methanol.testing.SubmittableSubscription
- awaitCall() - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient
- awaitCancellation() - Method in class com.github.mizosoft.methanol.testing.TestSubscription
- awaitCompletion() - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- awaitCompletion(Duration) - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- awaitError() - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- awaitError(Duration) - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- awaitNext(long, TimeUnit) - Method in class com.github.mizosoft.methanol.testing.MockExecutor
- awaitRequest() - Method in class com.github.mizosoft.methanol.testing.TestSubscription
- awaitSubscription() - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- awaitSubscription(Duration) - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- awaitUnchecked(CountDownLatch) - Static method in class com.github.mizosoft.methanol.testing.TestUtils
- awaitUnchecked(CyclicBarrier) - Static method in class com.github.mizosoft.methanol.testing.TestUtils
B
- backendInterceptor(Methanol.Interceptor) - Method in class com.github.mizosoft.methanol.Methanol.BaseBuilder
-
Adds an interceptor that is invoked right before the request is forwarded to the client's backend.
- backendInterceptors() - Method in class com.github.mizosoft.methanol.Methanol
-
Returns an immutable list of this client's
backend interceptors
. - baseUri() - Method in class com.github.mizosoft.methanol.Methanol
-
Returns this client's base
URI
. - baseUri(String) - Method in class com.github.mizosoft.methanol.Methanol.BaseBuilder
- baseUri(URI) - Method in class com.github.mizosoft.methanol.Methanol.BaseBuilder
- basic() - Method in class com.github.mizosoft.methanol.AdapterCodec.Builder
- basic() - Static method in interface com.github.mizosoft.methanol.BodyAdapter.Decoder
-
Returns the basic decoder.
- basic() - Static method in interface com.github.mizosoft.methanol.BodyAdapter.Encoder
-
Returns the basic encoder.
- BasicAdapter - Class in com.github.mizosoft.methanol.internal.adapter
-
An adapter for basic types (e.g.,
String
,byte[]
). - basicDecoder() - Method in class com.github.mizosoft.methanol.AdapterCodec.Builder
-
Adds the
basic decoder
. - basicEncoder() - Method in class com.github.mizosoft.methanol.AdapterCodec.Builder
-
Adds the
basic encoder
. - bindings() - Static method in class com.github.mizosoft.methanol.internal.spi.BodyDecoderFactoryProviders
- body() - Method in class com.github.mizosoft.methanol.testing.HttpResponseStub
- body() - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.BodySubscriberVerifier
- body(U) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- BodyAdapter - Interface in com.github.mizosoft.methanol
-
An object that converts objects to or from request or response bodies respectively, using a defined format.
- BodyAdapter.Decoder - Interface in com.github.mizosoft.methanol
-
A
BodyAdapter
that decodes response bodies into objects. - BodyAdapter.Encoder - Interface in com.github.mizosoft.methanol
-
A
BodyAdapter
that encodes objects into request bodies. - BodyAdapter.Hints - Interface in com.github.mizosoft.methanol
-
A collections of hints that provide additional context to customize an adapter's encoding/decoding behavior.
- BodyAdapter.Hints.Builder - Class in com.github.mizosoft.methanol
-
A builder of
Hint
objects. - BodyAdapterVerifier<A,
VERIFIER> - Class in com.github.mizosoft.methanol.testing.verifiers -
A small DSL for testing
BodyAdapter
implementations. - BodyDecoder<T> - Interface in com.github.mizosoft.methanol
-
A
HttpResponse.BodySubscriber
that decodes the response body for consumption by a downstream subscriber. - BodyDecoder.Factory - Interface in com.github.mizosoft.methanol
-
A factory of
BodyDecoders
for some defined encoding. - BodyDecoderFactoryProviders - Class in com.github.mizosoft.methanol.internal.spi
-
Utility class for finding decoder factories.
- bodyHandler() - Static method in class com.github.mizosoft.methanol.internal.extensions.PublisherBodySubscriber
- bodyHandler() - Method in interface com.github.mizosoft.methanol.Methanol.Interceptor.Chain
-
Returns the
BodyHandler
this chain uses for handling the response. - bodyHandler() - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient.Call
- bodyPublisher() - Method in class com.github.mizosoft.methanol.MultipartBodyPublisher.Part
-
Returns the
BodyPublisher
of this part's content. - bodyPublisher() - Method in class com.github.mizosoft.methanol.MutableRequest
- BodyPublisherVerifier - Class in com.github.mizosoft.methanol.testing.verifiers
-
A small DSL for testing
BodyPublisher
implementations. - BodyPublisherVerifier(HttpRequest.BodyPublisher) - Constructor for class com.github.mizosoft.methanol.testing.verifiers.BodyPublisherVerifier
- BodySubscriberVerifier(HttpResponse.BodySubscriber<T>) - Constructor for class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.BodySubscriberVerifier
- boundary() - Method in class com.github.mizosoft.methanol.MultipartBodyPublisher
-
Returns the boundary of this multipart body.
- boundary(String) - Method in class com.github.mizosoft.methanol.MultipartBodyPublisher.Builder
-
Sets the boundary of the multipart body.
- BOUNDARY_MATCHER - Static variable in class com.github.mizosoft.methanol.internal.text.HttpCharMatchers
- BrotliBodyDecoderFactory - Class in com.github.mizosoft.methanol.brotli.internal
-
BodyDecoder.Factory
provider for brotli encoding. - BrotliBodyDecoderFactory() - Constructor for class com.github.mizosoft.methanol.brotli.internal.BrotliBodyDecoderFactory
-
Creates a new
BrotliBodyDecoderFactory
. - BUFFER_SIZE - Static variable in class com.github.mizosoft.methanol.internal.Utils
- BUFFERS_PER_LIST - Static variable in class com.github.mizosoft.methanol.testing.TestUtils
-
The number of buffers to use for
List<ByteBuffer>
streams. - BufferTokenizer - Class in com.github.mizosoft.methanol.testing
- build() - Method in class com.github.mizosoft.methanol.AdapterCodec.Builder
-
Returns a new
AdapterCodec
containing the encoders and decoders added so far. - build() - Method in class com.github.mizosoft.methanol.BodyAdapter.Hints.Builder
-
Returns a new
Hints
object containing the hints added so far. - build() - Method in class com.github.mizosoft.methanol.CacheControl.Builder
-
Builds a new
Cache-Control
. - build() - Method in class com.github.mizosoft.methanol.FormBodyPublisher.Builder
-
Returns a new
FormBodyPublisher
with the added queries. - build() - Method in class com.github.mizosoft.methanol.HttpCache.Builder
-
Creates a new
HttpCache
. - build() - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore.Builder
- build() - Method in class com.github.mizosoft.methanol.internal.extensions.HeadersBuilder
- build() - Method in class com.github.mizosoft.methanol.Methanol.BaseBuilder
-
Creates a new
Methanol
instance. - build() - Method in class com.github.mizosoft.methanol.MultipartBodyPublisher.Builder
-
Returns a new
MultipartBodyPublisher
. - build() - Method in class com.github.mizosoft.methanol.MutableRequest
-
Returns an immutable copy of this request.
- build() - Method in class com.github.mizosoft.methanol.ProgressTracker.Builder
-
Builds a new
ProgressTracker
. - build() - Method in class com.github.mizosoft.methanol.ResponseBuilder
- build() - Method in class com.github.mizosoft.methanol.store.redis.RedisStorageExtension.Builder
-
Creates a new
RedisStorageExtension
. - build() - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
- build() - Method in class com.github.mizosoft.methanol.testing.MockGzipStream.Builder
- buildAsync() - Method in class com.github.mizosoft.methanol.HttpCache.Builder
-
Asynchronously creates a new
HttpCache
. - buildCacheAwareResponse() - Method in class com.github.mizosoft.methanol.ResponseBuilder
- Builder() - Constructor for class com.github.mizosoft.methanol.MultipartBodyPublisher.Builder
- buildTrackedResponse() - Method in class com.github.mizosoft.methanol.ResponseBuilder
- ByteBufferBodyPublisher - Class in com.github.mizosoft.methanol.internal.extensions
- ByteBufferBodyPublisher(ByteBuffer) - Constructor for class com.github.mizosoft.methanol.internal.extensions.ByteBufferBodyPublisher
- ByteBufferBodyPublisher(ByteBuffer, int) - Constructor for class com.github.mizosoft.methanol.internal.extensions.ByteBufferBodyPublisher
- ByteBufferCollector - Class in com.github.mizosoft.methanol.testing
-
Collects a stream of
ByteBuffers
. - ByteBufferIterator - Class in com.github.mizosoft.methanol.testing
- ByteBufferIterator(ByteBuffer, int) - Constructor for class com.github.mizosoft.methanol.testing.ByteBufferIterator
- ByteBufferListIterator - Class in com.github.mizosoft.methanol.testing
- ByteBufferListIterator(ByteBuffer, int, int) - Constructor for class com.github.mizosoft.methanol.testing.ByteBufferListIterator
- byteChannel() - Method in class com.github.mizosoft.methanol.WritableBodyPublisher
-
Returns a
WritableByteChannel
for writing this body's content. - ByteChannelBodySubscriber - Class in com.github.mizosoft.methanol.internal.extensions
-
A subscriber that exposes the flow of bytes as a
ReadableByteChannel
. - ByteChannelBodySubscriber() - Constructor for class com.github.mizosoft.methanol.internal.extensions.ByteChannelBodySubscriber
- bytesTransferred() - Method in interface com.github.mizosoft.methanol.ProgressTracker.Progress
-
Returns the number of transferred bytes for this event.
- bytesTransferredThreshold() - Method in class com.github.mizosoft.methanol.ProgressTracker
-
Returns the minimum number of bytes to be transferred for a progress event to be signalled.
- bytesTransferredThreshold(long) - Method in class com.github.mizosoft.methanol.ProgressTracker.Builder
-
Sets the minimum number of transferred bytes for a progress event to be signalled.
C
- cache() - Method in class com.github.mizosoft.methanol.Methanol
-
Returns this client's
cache
. - cache(HttpCache) - Method in class com.github.mizosoft.methanol.Methanol.Builder
-
Sets the
HttpCache
to be used by the client. - CacheAwareResponse<T> - Interface in com.github.mizosoft.methanol
-
A
TrackedResponse
that knows it may have been generated from an HTTP cache. - CacheAwareResponse.CacheStatus - Enum Class in com.github.mizosoft.methanol
-
The status of an attempt to retrieve an HTTP response from cache.
- cacheChain(List<HttpCache>) - Method in class com.github.mizosoft.methanol.Methanol.Builder
-
Sets a chain of caches to be called one after another, in the order specified by the given list.
- cacheControl(CacheControl) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Sets the
Cache-Control
header to the given value. - CacheControl - Class in com.github.mizosoft.methanol
-
A group of cache directives.
- CacheControl.Builder - Class in com.github.mizosoft.methanol
-
A builder of
CacheControl
instances, with explicit directive setters for request cache directives. - CACHED_POOL - Enum constant in enum class com.github.mizosoft.methanol.testing.ExecutorExtension.ExecutorType
- CacheInterceptor - Class in com.github.mizosoft.methanol.internal.cache
-
An
Methanol.Interceptor
that serves incoming requests from cache, network, both (in case of successful/failed revalidation), or none (in case of unsatisfiable requests). - CacheInterceptor(LocalCache.Factory, HttpCache.Listener, Executor, Clock) - Constructor for class com.github.mizosoft.methanol.internal.cache.CacheInterceptor
- cacheOn(StorageExtension) - Method in class com.github.mizosoft.methanol.HttpCache.Builder
- cacheOnDisk(Path, long) - Method in class com.github.mizosoft.methanol.HttpCache.Builder
-
Specifies that HTTP responses are to be persisted on disk, under the given directory, with the given size bound.
- cacheOnMemory(long) - Method in class com.github.mizosoft.methanol.HttpCache.Builder
-
Specifies that HTTP responses are to be cached on memory with the given size bound.
- CacheReadingPublisher - Class in com.github.mizosoft.methanol.internal.cache
-
Publisher for the response body as read from a cached entry's
Store.Viewer
. - CacheReadingPublisher(Store.Viewer, Executor) - Constructor for class com.github.mizosoft.methanol.internal.cache.CacheReadingPublisher
- CacheReadingPublisher(Store.Viewer, Executor, CacheReadingPublisher.Listener) - Constructor for class com.github.mizosoft.methanol.internal.cache.CacheReadingPublisher
- CacheReadingPublisher(Store.Viewer, Executor, CacheReadingPublisher.Listener, int) - Constructor for class com.github.mizosoft.methanol.internal.cache.CacheReadingPublisher
- CacheReadingPublisher.Listener - Interface in com.github.mizosoft.methanol.internal.cache
- cacheResponse() - Method in interface com.github.mizosoft.methanol.CacheAwareResponse
-
Returns an
Optional
for the response constructed from cache. - cacheResponse() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- cacheResponse(TrackedResponse<?>) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- CacheResponse - Class in com.github.mizosoft.methanol.internal.cache
-
A
RawResponse
retrieved from cache. - CacheResponse(TrackedResponse<?>, Store.Viewer, Executor, CacheReadingPublisher.Listener, HttpRequest, Instant) - Constructor for class com.github.mizosoft.methanol.internal.cache.CacheResponse
- CacheResponseMetadata - Class in com.github.mizosoft.methanol.internal.cache
-
Metadata for each response entry in the cache.
- caches() - Method in class com.github.mizosoft.methanol.Methanol
- cacheStatus() - Method in interface com.github.mizosoft.methanol.CacheAwareResponse
-
Returns this response's
CacheAwareResponse.CacheStatus
. - cacheStatus(CacheAwareResponse.CacheStatus) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- CacheWritingPublisher - Class in com.github.mizosoft.methanol.internal.cache
-
A
Publisher
that writes the body stream into cache while simultaneously forwarding it to downstream. - CacheWritingPublisher(Flow.Publisher<List<ByteBuffer>>, Store.Editor, ByteBuffer, Executor) - Constructor for class com.github.mizosoft.methanol.internal.cache.CacheWritingPublisher
- CacheWritingPublisher(Flow.Publisher<List<ByteBuffer>>, Store.Editor, ByteBuffer, Executor, CacheWritingPublisher.Listener) - Constructor for class com.github.mizosoft.methanol.internal.cache.CacheWritingPublisher
- CacheWritingPublisher(Flow.Publisher<List<ByteBuffer>>, Store.Editor, ByteBuffer, Executor, CacheWritingPublisher.Listener, boolean) - Constructor for class com.github.mizosoft.methanol.internal.cache.CacheWritingPublisher
- CacheWritingPublisher.Listener - Interface in com.github.mizosoft.methanol.internal.cache
- cancel() - Method in class com.github.mizosoft.methanol.internal.flow.AbstractSubscription
- cancel() - Method in class com.github.mizosoft.methanol.internal.flow.Upstream
-
Cancels the upstream if set.
- cancel() - Method in class com.github.mizosoft.methanol.testing.TestSubscription
- cancel(boolean) - Method in class com.github.mizosoft.methanol.internal.flow.Upstream
- cancellationCount() - Method in class com.github.mizosoft.methanol.testing.TestSubscription
- cancelOnComplete(Flow.Subscriber<? super T>) - Method in class com.github.mizosoft.methanol.internal.flow.AbstractSubscription
-
Calls downstream's
onComplete
after cancelling this subscription. - cancelOnError(Flow.Subscriber<? super T>, Throwable, boolean) - Method in class com.github.mizosoft.methanol.internal.flow.AbstractSubscription
-
Calls downstream's
onError
with the given exception after cancelling this subscription. - castNonNull(T) - Static method in class com.github.mizosoft.methanol.internal.Validate
-
Copied from checker-framework's
NullnessUtil
to avoid a runtime dependency. - CharMatcher - Interface in com.github.mizosoft.methanol.internal.text
-
Char matching API to use internally.
- CharSequenceEncoder - Class in com.github.mizosoft.methanol.testing
- CharSequenceEncoder() - Constructor for class com.github.mizosoft.methanol.testing.CharSequenceEncoder
- charset() - Method in class com.github.mizosoft.methanol.MediaType
-
Returns an
Optional
representing the value of the charset parameter. - charsetOrDefault(MediaType, Charset) - Static method in class com.github.mizosoft.methanol.adapter.AbstractBodyAdapter
-
Returns either the result of
MediaType.charsetOrDefault(Charset)
, or the given charset if the given media type isnull
. - charsetOrDefault(Charset) - Method in class com.github.mizosoft.methanol.MediaType
-
Returns either the value of the charset parameter or the given default charset if no such parameter exists or if the charset has no support in this JVM.
- charsetOrUtf8() - Method in class com.github.mizosoft.methanol.MediaType
-
Equivalent to calling
charsetOrDefault(StandardCharsets.UTF_8)
. - charsetOrUtf8(MediaType) - Static method in class com.github.mizosoft.methanol.adapter.AbstractBodyAdapter
-
Returns either the result of
MediaType.charsetOrDefault(Charset)
, orUTF-8
if the given media type isnull
. - clear() - Method in class com.github.mizosoft.methanol.HttpCache
-
Removes all entries from this cache.
- clear() - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore
- clear() - Method in class com.github.mizosoft.methanol.internal.cache.MemoryStore
- clear() - Method in interface com.github.mizosoft.methanol.internal.cache.Store
-
Removes all entries from this store.
- clear() - Method in class com.github.mizosoft.methanol.internal.extensions.HeadersBuilder
- clear() - Method in class com.github.mizosoft.methanol.internal.flow.Upstream
-
Just loses the reference to upstream if cancellation it is not required.
- clock(Clock) - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore.Builder
- close() - Method in interface com.github.mizosoft.methanol.decoder.AsyncDecoder
-
Releases any resources associated with the decoder.
- close() - Method in class com.github.mizosoft.methanol.HttpCache
-
Closes this cache.
- close() - Method in class com.github.mizosoft.methanol.internal.cache.CacheResponse
- close() - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore
- close() - Method in class com.github.mizosoft.methanol.internal.cache.MemoryStore
- close() - Method in interface com.github.mizosoft.methanol.internal.cache.Store
-
Closes this store.
- close() - Method in interface com.github.mizosoft.methanol.internal.cache.Store.Editor
-
Closes this editor.
- close() - Method in interface com.github.mizosoft.methanol.internal.cache.Store.Viewer
-
Closes this viewer.
- close() - Method in interface com.github.mizosoft.methanol.ResponsePayload
-
Makes sure the resources held by this payload are released.
- close() - Method in interface com.github.mizosoft.methanol.store.redis.RedisConnectionProvider
-
Releases the resources associated with this
RedisConnectionProvider
. - close() - Method in class com.github.mizosoft.methanol.testing.CloseableCopyOnWriteList
- close() - Method in class com.github.mizosoft.methanol.testing.ExecutorContext
- close() - Method in class com.github.mizosoft.methanol.testing.file.ForwardingAsynchronousFileChannel
- close() - Method in class com.github.mizosoft.methanol.testing.file.WindowsEmulatingFileSystem
- close() - Method in class com.github.mizosoft.methanol.testing.file.LeakDetectingFileSystem
- close() - Method in class com.github.mizosoft.methanol.testing.store.RedisClusterSession
- close() - Method in interface com.github.mizosoft.methanol.testing.store.RedisSession
- close() - Method in class com.github.mizosoft.methanol.testing.store.RedisStandaloneSession
- close() - Method in class com.github.mizosoft.methanol.testing.store.StoreContext
- close() - Method in class com.github.mizosoft.methanol.testing.SubmittablePublisher
- close() - Method in class com.github.mizosoft.methanol.testing.TestSubscriberContext
- close() - Method in class com.github.mizosoft.methanol.WritableBodyPublisher
-
Unless already closed, causes the subscribed (or yet to subscribe) client to be completed after the content written so far has been consumed.
- CloseableCopyOnWriteList<T> - Class in com.github.mizosoft.methanol.testing
-
A minimal thread-safe list that create a new copy of the array whenever a new item is added.
- closeExceptionally(Throwable) - Method in class com.github.mizosoft.methanol.testing.SubmittablePublisher
- closeExceptionally(Throwable) - Method in class com.github.mizosoft.methanol.WritableBodyPublisher
-
Unless already closed, causes the subscribed (or yet to subscribe) client to fail with the given exception.
- cluster(RedisConnectionProvider<StatefulRedisClusterConnection<String, ByteBuffer>>) - Method in class com.github.mizosoft.methanol.store.redis.RedisStorageExtension.Builder
-
Specifies the connection provider used to connect to the Redis Cluster instance.
- cluster(RedisClusterClient) - Method in class com.github.mizosoft.methanol.store.redis.RedisStorageExtension.Builder
-
Specifies the client used to connect to the Redis Cluster instance.
- cluster(Iterable<RedisURI>) - Method in class com.github.mizosoft.methanol.store.redis.RedisStorageExtension.Builder
-
Specifies one or more URIs for discovering the topology of the Redis Cluster instance.
- CM - Enum constant in enum class com.github.mizosoft.methanol.testing.MockGzipStream.CorruptionMode
- collect(Collection<ByteBuffer>) - Static method in class com.github.mizosoft.methanol.testing.ByteBufferCollector
- collect(Flow.Publisher<ByteBuffer>) - Static method in class com.github.mizosoft.methanol.testing.ByteBufferCollector
- collectMulti(Collection<List<ByteBuffer>>) - Static method in class com.github.mizosoft.methanol.testing.ByteBufferCollector
- collectMulti(Flow.Publisher<List<ByteBuffer>>) - Static method in class com.github.mizosoft.methanol.testing.ByteBufferCollector
- com.github.mizosoft.methanol - package com.github.mizosoft.methanol
- com.github.mizosoft.methanol.adapter - package com.github.mizosoft.methanol.adapter
- com.github.mizosoft.methanol.adapter.gson - package com.github.mizosoft.methanol.adapter.gson
- com.github.mizosoft.methanol.adapter.jackson - package com.github.mizosoft.methanol.adapter.jackson
- com.github.mizosoft.methanol.adapter.jackson.flux - package com.github.mizosoft.methanol.adapter.jackson.flux
- com.github.mizosoft.methanol.adapter.jaxb - package com.github.mizosoft.methanol.adapter.jaxb
- com.github.mizosoft.methanol.adapter.jaxb.jakarta - package com.github.mizosoft.methanol.adapter.jaxb.jakarta
- com.github.mizosoft.methanol.adapter.moshi - package com.github.mizosoft.methanol.adapter.moshi
- com.github.mizosoft.methanol.adapter.protobuf - package com.github.mizosoft.methanol.adapter.protobuf
- com.github.mizosoft.methanol.brotli.internal - package com.github.mizosoft.methanol.brotli.internal
- com.github.mizosoft.methanol.decoder - package com.github.mizosoft.methanol.decoder
- com.github.mizosoft.methanol.function - package com.github.mizosoft.methanol.function
- com.github.mizosoft.methanol.internal - package com.github.mizosoft.methanol.internal
- com.github.mizosoft.methanol.internal.adapter - package com.github.mizosoft.methanol.internal.adapter
- com.github.mizosoft.methanol.internal.annotations - package com.github.mizosoft.methanol.internal.annotations
- com.github.mizosoft.methanol.internal.cache - package com.github.mizosoft.methanol.internal.cache
- com.github.mizosoft.methanol.internal.concurrent - package com.github.mizosoft.methanol.internal.concurrent
- com.github.mizosoft.methanol.internal.decoder - package com.github.mizosoft.methanol.internal.decoder
- com.github.mizosoft.methanol.internal.extensions - package com.github.mizosoft.methanol.internal.extensions
- com.github.mizosoft.methanol.internal.flow - package com.github.mizosoft.methanol.internal.flow
- com.github.mizosoft.methanol.internal.function - package com.github.mizosoft.methanol.internal.function
- com.github.mizosoft.methanol.internal.spi - package com.github.mizosoft.methanol.internal.spi
- com.github.mizosoft.methanol.internal.text - package com.github.mizosoft.methanol.internal.text
- com.github.mizosoft.methanol.internal.util - package com.github.mizosoft.methanol.internal.util
- com.github.mizosoft.methanol.kotlin - package com.github.mizosoft.methanol.kotlin
- com.github.mizosoft.methanol.store.redis - package com.github.mizosoft.methanol.store.redis
- com.github.mizosoft.methanol.testing - package com.github.mizosoft.methanol.testing
- com.github.mizosoft.methanol.testing.decoder - package com.github.mizosoft.methanol.testing.decoder
- com.github.mizosoft.methanol.testing.file - package com.github.mizosoft.methanol.testing.file
- com.github.mizosoft.methanol.testing.store - package com.github.mizosoft.methanol.testing.store
- com.github.mizosoft.methanol.testing.verifiers - package com.github.mizosoft.methanol.testing.verifiers
- commit(Store.Editor, String) - Static method in class com.github.mizosoft.methanol.testing.store.StoreTesting
- commit(Store.Editor, String, String) - Static method in class com.github.mizosoft.methanol.testing.store.StoreTesting
- commit(ByteBuffer) - Method in interface com.github.mizosoft.methanol.internal.cache.Store.Editor
-
Synchronous variant of
Store.Editor.commit(ByteBuffer, Executor)
. - commit(ByteBuffer, Executor) - Method in interface com.github.mizosoft.methanol.internal.cache.Store.Editor
-
Commits the changes made so far.
- Compare - Class in com.github.mizosoft.methanol.internal.util
- compatibleMediaTypes() - Method in class com.github.mizosoft.methanol.adapter.AbstractBodyAdapter
-
Returns an immutable set containing the media types this adapter is compatible with.
- complete() - Method in class com.github.mizosoft.methanol.internal.flow.AbstractQueueSubscription
- complete() - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient.Call
- complete() - Method in class com.github.mizosoft.methanol.testing.SubmittableSubscription
- complete(ByteBuffer) - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient.Call
- completedBody() - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.BodySubscriberVerifier
- completeExceptionally(Throwable) - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient.Call
- completionCount() - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- CONDITIONAL_HIT - Enum constant in enum class com.github.mizosoft.methanol.CacheAwareResponse.CacheStatus
-
The response was constructed from cache but a conditional
GET
had to be made to validate it with the server. - conditionalize(HttpRequest) - Method in class com.github.mizosoft.methanol.internal.cache.CacheResponse
- config() - Method in class com.github.mizosoft.methanol.testing.store.RedisClusterStoreContext
- config() - Method in class com.github.mizosoft.methanol.testing.store.RedisStandaloneStoreContext
- config() - Method in class com.github.mizosoft.methanol.testing.store.DiskStoreContext
- config() - Method in class com.github.mizosoft.methanol.testing.store.StoreContext
- connect() - Method in class com.github.mizosoft.methanol.testing.store.RedisClusterSession
- connect() - Method in class com.github.mizosoft.methanol.testing.store.RedisClusterStoreContext
- connect() - Method in interface com.github.mizosoft.methanol.testing.store.RedisSession
-
Returns a connection to the redis server represented by this session.
- connect() - Method in class com.github.mizosoft.methanol.testing.store.RedisStandaloneSession
- connect() - Method in class com.github.mizosoft.methanol.testing.store.RedisStandaloneStoreContext
- connectAsync() - Method in interface com.github.mizosoft.methanol.store.redis.RedisConnectionProvider
-
Asynchronously connects to Redis and returns the connection.
- connectTimeout() - Method in class com.github.mizosoft.methanol.Methanol
- connectTimeout() - Method in class com.github.mizosoft.methanol.testing.HttpClientStub
- connectTimeout() - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient
- connectTimeout(Duration) - Method in class com.github.mizosoft.methanol.Methanol.Builder
- consumeCharIfPresent(char) - Method in class com.github.mizosoft.methanol.internal.text.HeaderValueTokenizer
- consumeCharsMatching(CharMatcher) - Method in class com.github.mizosoft.methanol.internal.text.HeaderValueTokenizer
- consumeDelimiter(char) - Method in class com.github.mizosoft.methanol.internal.text.HeaderValueTokenizer
- consumeDelimiter(char, boolean) - Method in class com.github.mizosoft.methanol.internal.text.HeaderValueTokenizer
- consumeIfPresent(String) - Method in class com.github.mizosoft.methanol.internal.text.HeaderValueTokenizer
- consumer(ThrowingConsumer<T>) - Static method in class com.github.mizosoft.methanol.internal.function.Unchecked
- containsHeader(String, long) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- containsHeader(String, String) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- containsHeader(String, String) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- containsHeader(String, List<String>) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- containsHeaders(HttpHeaders) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- containsHeaders(Map<String, List<String>>) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- containsHeadersExactly(String...) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- containsHeadersExactly(HttpHeaders) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- containsHeadersExactly(HttpHeaders) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- containsHeadersExactlyDiscardingStrippedContentEncoding(HttpHeaders) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- containsRequestHeader(String, String) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- containsRequestHeadersExactly(String...) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- containsRequestHeadersExactly(HttpHeaders) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- containsTag(TypeRef<T>, T) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- containsTag(Class<T>, T) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- contentLength() - Method in class com.github.mizosoft.methanol.FormBodyPublisher
- contentLength() - Method in class com.github.mizosoft.methanol.internal.extensions.ByteBufferBodyPublisher
- contentLength() - Method in class com.github.mizosoft.methanol.internal.extensions.ForwardingBodyPublisher
- contentLength() - Method in class com.github.mizosoft.methanol.internal.extensions.SupplierBodyPublisher
- contentLength() - Method in class com.github.mizosoft.methanol.MultipartBodyPublisher
- contentLength() - Method in interface com.github.mizosoft.methanol.ProgressTracker.Progress
-
Returns content length, or a value less than zero if unknown.
- contentLength() - Method in class com.github.mizosoft.methanol.WritableBodyPublisher
- converting(TypeRef<T>) - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier
- converting(Class<T>) - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier
- converting(T) - Method in class com.github.mizosoft.methanol.testing.verifiers.EncoderVerifier
- converting(T, TypeRef<T>) - Method in class com.github.mizosoft.methanol.testing.verifiers.EncoderVerifier
- cookieHandler() - Method in class com.github.mizosoft.methanol.Methanol
- cookieHandler() - Method in class com.github.mizosoft.methanol.testing.HttpClientStub
- cookieHandler() - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient
- cookieHandler(CookieHandler) - Method in class com.github.mizosoft.methanol.Methanol.Builder
- copy() - Method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a copy of this request that is independent of this instance.
- copy() - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
- copy(ByteBuffer) - Static method in class com.github.mizosoft.methanol.internal.Utils
- copyOf(HttpRequest) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
that is a copy of the given request. - copyRemaining(ByteBuffer, ByteBuffer) - Static method in class com.github.mizosoft.methanol.internal.Utils
- copyRemaining(ByteBuffer, ByteBuffer) - Static method in class com.github.mizosoft.methanol.testing.TestUtils
- corrupt(MockGzipStream.CorruptionMode, int) - Method in class com.github.mizosoft.methanol.testing.MockGzipStream.Builder
- CRC32 - Enum constant in enum class com.github.mizosoft.methanol.testing.MockGzipStream.CorruptionMode
- create() - Static method in interface com.github.mizosoft.methanol.adapter.jaxb.jakarta.JaxbBindingFactory
-
Returns a new
JaxbBindingFactory
that creates and cachesJAXBContexts
for each requested type. - create() - Static method in interface com.github.mizosoft.methanol.adapter.jaxb.JaxbBindingFactory
-
Returns a new
JaxbBindingFactory
that creates and cachesJAXBContexts
for each requested type. - create() - Static method in class com.github.mizosoft.methanol.Methanol
-
Creates a default
Methanol
instance. - create() - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
. - create() - Static method in class com.github.mizosoft.methanol.ProgressTracker
-
Returns a default
ProgressTracker
with no thresholds or executor. - create() - Static method in class com.github.mizosoft.methanol.WritableBodyPublisher
-
Returns a new
WritableBodyPublisher
. - create(int) - Static method in class com.github.mizosoft.methanol.WritableBodyPublisher
-
Returns a new
WritableBodyPublisher
with the given buffer size. - create(String) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a default GET method. - create(HttpHeaders, HttpRequest.BodyPublisher) - Static method in class com.github.mizosoft.methanol.MultipartBodyPublisher.Part
-
Returns a new
Part
with the given headers and body publisher. - create(HttpResponse.BodySubscriber<T>) - Method in interface com.github.mizosoft.methanol.BodyDecoder.Factory
-
Creates and returns a
BodyDecoder
with the given downstream. - create(HttpResponse.BodySubscriber<T>) - Method in class com.github.mizosoft.methanol.brotli.internal.BrotliBodyDecoderFactory
- create(HttpResponse.BodySubscriber<T>) - Method in class com.github.mizosoft.methanol.internal.decoder.DeflateBodyDecoderFactory
- create(HttpResponse.BodySubscriber<T>) - Method in class com.github.mizosoft.methanol.internal.decoder.GzipBodyDecoderFactory
- create(HttpResponse.BodySubscriber<T>, Executor) - Method in interface com.github.mizosoft.methanol.BodyDecoder.Factory
-
Creates and returns a
BodyDecoder
with the given downstream and executor. - create(HttpResponse.BodySubscriber<T>, Executor) - Method in class com.github.mizosoft.methanol.brotli.internal.BrotliBodyDecoderFactory
- create(HttpResponse.BodySubscriber<T>, Executor) - Method in class com.github.mizosoft.methanol.internal.decoder.DeflateBodyDecoderFactory
- create(HttpResponse.BodySubscriber<T>, Executor) - Method in class com.github.mizosoft.methanol.internal.decoder.GzipBodyDecoderFactory
- create(URI) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a default GET method. - create(Function<HttpRequest, HttpRequest>) - Static method in interface com.github.mizosoft.methanol.Methanol.Interceptor
-
Returns an interceptor that forwards the request after applying the given operator.
- createAndRegisterStore() - Method in class com.github.mizosoft.methanol.testing.store.StoreContext
- createConcurrentPerUriRecorder() - Static method in interface com.github.mizosoft.methanol.HttpCache.StatsRecorder
-
Creates a
StatsRecorder
that atomically increments each count and records perURI
stats. - createConcurrentRecorder() - Static method in interface com.github.mizosoft.methanol.HttpCache.StatsRecorder
-
Creates a
StatsRecorder
that atomically increments each count and doesn't record perURI
stats. - createConfig(List<?>) - Static method in class com.github.mizosoft.methanol.testing.store.StoreExtension
- createDecoder() - Static method in class com.github.mizosoft.methanol.adapter.gson.GsonAdapterFactory
-
Returns a
BodyAdapter.Decoder
that uses a defaultGson
instance. - createDecoder() - Static method in class com.github.mizosoft.methanol.adapter.jackson.flux.JacksonFluxAdapterFactory
-
Returns a
Decoder
that uses a defaultObjectMapper
instance. - createDecoder() - Static method in class com.github.mizosoft.methanol.adapter.jackson.JacksonAdapterFactory
-
Deprecated.
- createDecoder() - Static method in class com.github.mizosoft.methanol.adapter.jaxb.jakarta.JaxbAdapterFactory
-
Returns a new
Decoder
using the default caching factory. - createDecoder() - Static method in class com.github.mizosoft.methanol.adapter.jaxb.JaxbAdapterFactory
-
Returns a new
Decoder
using the default caching factory. - createDecoder() - Static method in class com.github.mizosoft.methanol.adapter.protobuf.ProtobufAdapterFactory
-
Returns a new
BodyAdapter.Decoder
with an empty extension registry. - createDecoder(ObjectMapper) - Static method in class com.github.mizosoft.methanol.adapter.jackson.flux.JacksonFluxAdapterFactory
-
Returns a
Decoder
that uses the givenObjectMapper
instance. - createDecoder(ObjectMapper) - Static method in class com.github.mizosoft.methanol.adapter.jackson.JacksonAdapterFactory
-
Deprecated.
- createDecoder(ObjectMapper, ObjectReaderFactory, MediaType, MediaType...) - Static method in class com.github.mizosoft.methanol.adapter.jackson.JacksonAdapterFactory
-
Returns a
BodyAdapter.Decoder
that uses the givenObjectMapper
and is compatible with the given media types. - createDecoder(ObjectMapper, MediaType, MediaType...) - Static method in class com.github.mizosoft.methanol.adapter.jackson.JacksonAdapterFactory
-
Returns a
BodyAdapter.Decoder
that uses the givenObjectMapper
and is compatible with the given media types. - createDecoder(JaxbBindingFactory) - Static method in class com.github.mizosoft.methanol.adapter.jaxb.jakarta.JaxbAdapterFactory
-
Returns a new
Decoder
using the given factory. - createDecoder(JaxbBindingFactory) - Static method in class com.github.mizosoft.methanol.adapter.jaxb.JaxbAdapterFactory
-
Returns a new
Decoder
using the given factory. - createDecoder(Gson) - Static method in class com.github.mizosoft.methanol.adapter.gson.GsonAdapterFactory
-
Returns a
BodyAdapter.Decoder
that uses the givenGson
instance. - createDecoder(ExtensionRegistryLite) - Static method in class com.github.mizosoft.methanol.adapter.protobuf.ProtobufAdapterFactory
-
Returns a new
BodyAdapter.Decoder
that uses the given extension registry. - createDefault(StoreConfig.StoreType) - Static method in class com.github.mizosoft.methanol.testing.store.StoreConfig
- createEncoder() - Static method in class com.github.mizosoft.methanol.adapter.gson.GsonAdapterFactory
-
Returns a
BodyAdapter.Encoder
that uses a defaultGson
instance. - createEncoder() - Static method in class com.github.mizosoft.methanol.adapter.jackson.flux.JacksonFluxAdapterFactory
-
Returns a
Encoder
that uses a defaultObjectMapper
instance. - createEncoder() - Static method in class com.github.mizosoft.methanol.adapter.jackson.JacksonAdapterFactory
-
Deprecated.
- createEncoder() - Static method in class com.github.mizosoft.methanol.adapter.jaxb.jakarta.JaxbAdapterFactory
-
Returns a new
Encoder
using the default caching factory. - createEncoder() - Static method in class com.github.mizosoft.methanol.adapter.jaxb.JaxbAdapterFactory
-
Returns a new
Encoder
using the default caching factory. - createEncoder() - Static method in class com.github.mizosoft.methanol.adapter.protobuf.ProtobufAdapterFactory
-
Returns a new
BodyAdapter.Encoder
. - createEncoder(ObjectMapper) - Static method in class com.github.mizosoft.methanol.adapter.jackson.flux.JacksonFluxAdapterFactory
-
Returns a
Encoder
that uses the givenObjectMapper
instance. - createEncoder(ObjectMapper) - Static method in class com.github.mizosoft.methanol.adapter.jackson.JacksonAdapterFactory
-
Deprecated.
- createEncoder(ObjectMapper, ObjectWriterFactory, MediaType, MediaType...) - Static method in class com.github.mizosoft.methanol.adapter.jackson.JacksonAdapterFactory
-
Returns an
BodyAdapter.Encoder
that uses the givenObjectMapper
and is compatible with the given media types. - createEncoder(ObjectMapper, MediaType, MediaType...) - Static method in class com.github.mizosoft.methanol.adapter.jackson.JacksonAdapterFactory
-
Returns an
BodyAdapter.Encoder
that uses the givenObjectMapper
and is compatible with the given media types. - createEncoder(JaxbBindingFactory) - Static method in class com.github.mizosoft.methanol.adapter.jaxb.jakarta.JaxbAdapterFactory
-
Returns a new
Encoder
using the given factory. - createEncoder(JaxbBindingFactory) - Static method in class com.github.mizosoft.methanol.adapter.jaxb.JaxbAdapterFactory
-
Returns a new
Encoder
using the given factory. - createEncoder(Gson) - Static method in class com.github.mizosoft.methanol.adapter.gson.GsonAdapterFactory
-
Returns a
BodyAdapter.Encoder
that uses the givenGson
instance. - createExecutor(ExecutorExtension.ExecutorType) - Method in class com.github.mizosoft.methanol.testing.ExecutorContext
- createExecutor(ThreadFactory) - Method in enum class com.github.mizosoft.methanol.testing.ExecutorExtension.ExecutorType
- createJsonDecoder() - Static method in class com.github.mizosoft.methanol.adapter.jackson.JacksonAdapterFactory
-
Returns a
BodyAdapter.Decoder
that uses a defaultObjectMapper
for JSON and is only compatible withapplication/json
. - createJsonDecoder(ObjectMapper) - Static method in class com.github.mizosoft.methanol.adapter.jackson.JacksonAdapterFactory
-
Returns a
BodyAdapter.Decoder
that uses the givenObjectMapper
and is only compatible withapplication/json
. - createJsonEncoder() - Static method in class com.github.mizosoft.methanol.adapter.jackson.JacksonAdapterFactory
-
Returns an
BodyAdapter.Encoder
that uses a defaultObjectMapper
for JSON and is only compatible withapplication/json
. - createJsonEncoder(ObjectMapper) - Static method in class com.github.mizosoft.methanol.adapter.jackson.JacksonAdapterFactory
-
Returns an
BodyAdapter.Encoder
that uses the givenObjectMapper
and is only compatible withapplication/json
. - createMarshaller(Class<?>) - Method in interface com.github.mizosoft.methanol.adapter.jaxb.jakarta.JaxbBindingFactory
-
Returns a new
Marshaller
for encoding an object of the given class. - createMarshaller(Class<?>) - Method in interface com.github.mizosoft.methanol.adapter.jaxb.JaxbBindingFactory
-
Returns a new
Marshaller
for encoding an object of the given class. - createReader(ObjectMapper, TypeRef<?>) - Method in interface com.github.mizosoft.methanol.adapter.jackson.ObjectReaderFactory
-
Uses the given mapper to create an
ObjectReader
for the given type. - createStore(Executor, int) - Method in interface com.github.mizosoft.methanol.internal.cache.InternalStorageExtension
- createStoreAsync(Executor, int) - Method in interface com.github.mizosoft.methanol.internal.cache.InternalStorageExtension
- createSubscriber() - Method in class com.github.mizosoft.methanol.testing.TestSubscriberContext
- createSubscriber(Supplier<S>) - Method in class com.github.mizosoft.methanol.testing.TestSubscriberContext
- createUnmarshaller(Class<?>) - Method in interface com.github.mizosoft.methanol.adapter.jaxb.jakarta.JaxbBindingFactory
-
Returns a new
Unmarshaller
for decoding to an object of the given class. - createUnmarshaller(Class<?>) - Method in interface com.github.mizosoft.methanol.adapter.jaxb.JaxbBindingFactory
-
Returns a new
Unmarshaller
for decoding to an object of the given class. - createWriter(ObjectMapper, TypeRef<?>) - Method in interface com.github.mizosoft.methanol.adapter.jackson.ObjectWriterFactory
-
Uses the given mapper to create an
ObjectWriter
for the given type. - currentDemand() - Method in class com.github.mizosoft.methanol.internal.flow.AbstractSubscription
- currentDemand() - Method in class com.github.mizosoft.methanol.testing.SubmittableSubscription
- currentSink() - Method in interface com.github.mizosoft.methanol.decoder.AsyncDecoder.ByteSink
-
Returns a
ByteBuffer
with available space for writing the decompressed stream. - currentSource() - Method in interface com.github.mizosoft.methanol.decoder.AsyncDecoder.ByteSource
-
Returns a read-only
ByteBuffer
representing the currently available chunk.
D
- data(byte[]) - Method in class com.github.mizosoft.methanol.testing.MockGzipStream.Builder
- dataSize() - Method in interface com.github.mizosoft.methanol.internal.cache.Store.Viewer
-
Returns the size in bytes of the data stream.
- debugIndexOps(boolean) - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore.Builder
-
If set, the store complains when the index is accessed or modified either concurrently or not within the index executor.
- DebugUtils - Class in com.github.mizosoft.methanol.internal
- decode(AsyncDecoder.ByteSource, AsyncDecoder.ByteSink) - Method in interface com.github.mizosoft.methanol.decoder.AsyncDecoder
-
Processes whatever data available from the given source, writing decompressed bytes to the given sink.
- decode(AsyncDecoder, byte[], Decode.BufferSizeOption) - Static method in class com.github.mizosoft.methanol.testing.decoder.Decode
- decode(ByteBuffer) - Static method in class com.github.mizosoft.methanol.internal.cache.CacheResponseMetadata
- Decode - Class in com.github.mizosoft.methanol.testing.decoder
- Decode.BufferSizeOption - Enum Class in com.github.mizosoft.methanol.testing.decoder
- decoder() - Static method in class com.github.mizosoft.methanol.internal.adapter.BasicAdapter
- decoder(BodyAdapter.Decoder) - Method in class com.github.mizosoft.methanol.AdapterCodec.Builder
-
Adds the given decoder.
- decoders() - Method in class com.github.mizosoft.methanol.AdapterCodec
-
Returns the list of decoders in this codec.
- DecoderVerifier - Class in com.github.mizosoft.methanol.testing.verifiers
-
A small DSL for testing
BodyAdapter.Decoder
implementations. - DecoderVerifier(BodyAdapter.Decoder) - Constructor for class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier
- DecoderVerifier.BodyConversionStep<T> - Class in com.github.mizosoft.methanol.testing.verifiers
- DecoderVerifier.BodySubscriberVerifier<T> - Class in com.github.mizosoft.methanol.testing.verifiers
- DecoderVerifier.SupplierVerifier<T> - Class in com.github.mizosoft.methanol.testing.verifiers
- decoding(HttpResponse.BodyHandler<T>) - Static method in class com.github.mizosoft.methanol.MoreBodyHandlers
-
Returns a
BodyHandler
that decompresses the response body for the given handler using aBodyDecoder
. - decoding(HttpResponse.BodyHandler<T>, Executor) - Static method in class com.github.mizosoft.methanol.MoreBodyHandlers
-
Returns a
BodyHandler
that decompresses the response body for the given handler using aBodyDecoder
. - defaultHeader(String, String) - Method in class com.github.mizosoft.methanol.Methanol.BaseBuilder
-
Adds the given default header.
- defaultHeaders() - Method in class com.github.mizosoft.methanol.Methanol
-
Returns this client's default headers.
- defaultHeaders(String...) - Method in class com.github.mizosoft.methanol.Methanol.BaseBuilder
-
Adds each of the given default headers.
- defaultHeaders(Consumer<HeadersAccumulator<?>>) - Method in class com.github.mizosoft.methanol.Methanol.BaseBuilder
-
Configures the default headers as specified by the given consumer.
- DefaultProvider - Annotation Interface in com.github.mizosoft.methanol.internal.annotations
-
Identifies a provider from this module as default so that it can be overridden by user providers with same characteristics.
- deferredHandlerOf(TypeRef<T>, BodyAdapter.Hints) - Method in class com.github.mizosoft.methanol.AdapterCodec
-
Returns a
BodyHandler
that lazily decodes the response body into an object of the given type. - deferredSubscriberOf(TypeRef<T>, BodyAdapter.Hints) - Method in class com.github.mizosoft.methanol.AdapterCodec
-
Returns a
HttpResponse.BodySubscriber
that lazily decodes the response body into an object of the given type. - deflate(String) - Static method in class com.github.mizosoft.methanol.testing.TestUtils
- DeflateBodyDecoderFactory - Class in com.github.mizosoft.methanol.internal.decoder
-
BodyDecoder.Factory
for "deflate". - DeflateBodyDecoderFactory() - Constructor for class com.github.mizosoft.methanol.internal.decoder.DeflateBodyDecoderFactory
-
Creates a new
DeflateBodyDecoderFactory
. - delay() - Method in class com.github.mizosoft.methanol.testing.MockDelayer.DelayedFuture
- delay(Runnable, Duration, Executor) - Method in interface com.github.mizosoft.methanol.internal.concurrent.Delayer
-
Arranges for the task to be submitted to the given executor after the delay is evaluated.
- delay(Runnable, Duration, Executor) - Method in class com.github.mizosoft.methanol.testing.MockDelayer
- delayer(Delayer) - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore.Builder
- Delayer - Interface in com.github.mizosoft.methanol.internal.concurrent
-
Delays the execution of a given task.
- delegate() - Method in class com.github.mizosoft.methanol.adapter.ForwardingBodyAdapter
-
Returns the adapter calls are being forwarded to.
- delegate() - Method in class com.github.mizosoft.methanol.adapter.ForwardingDecoder
- delegate() - Method in class com.github.mizosoft.methanol.adapter.ForwardingEncoder
- delegate() - Method in class com.github.mizosoft.methanol.testing.file.ForwardingAsynchronousFileChannel
- delegate() - Method in class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- delegate() - Method in class com.github.mizosoft.methanol.testing.file.LeakDetectingFileSystem
- delegate() - Method in class com.github.mizosoft.methanol.testing.file.WindowsEmulatingFileSystem
- delegate() - Method in interface com.github.mizosoft.methanol.testing.file.ForwardingObject
- DELETE() - Method in class com.github.mizosoft.methanol.MutableRequest
- DELETE() - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
- DELETE(String) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a DELETE method. - DELETE(URI) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a DELETE method. - determinate() - Method in interface com.github.mizosoft.methanol.ProgressTracker.Progress
-
Returns
true
if this progress is determinate (i.e. - digits() - Static method in interface com.github.mizosoft.methanol.internal.text.CharMatcher
- directive(String) - Method in class com.github.mizosoft.methanol.CacheControl.Builder
-
Sets the given directive with no argument.
- directive(String, String) - Method in class com.github.mizosoft.methanol.CacheControl.Builder
-
Sets the given directive to the given argument.
- directives() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns a map of all directives and their arguments.
- directory() - Method in class com.github.mizosoft.methanol.HttpCache
-
Returns the directory used by this cache if entries are being cached on disk.
- directory() - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore
- directory() - Method in class com.github.mizosoft.methanol.testing.store.DiskStoreContext
- directory() - Method in class com.github.mizosoft.methanol.testing.store.RedisStandaloneSession
- directory(Path) - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore.Builder
- disable(Class<?>...) - Static method in class com.github.mizosoft.methanol.testing.Logging
- disable(String...) - Static method in class com.github.mizosoft.methanol.testing.Logging
- disabled() - Static method in interface com.github.mizosoft.methanol.HttpCache.StatsRecorder
-
Returns a disabled
StatsRecorder
. - disabled() - Static method in interface com.github.mizosoft.methanol.internal.cache.CacheReadingPublisher.Listener
- disabled() - Static method in interface com.github.mizosoft.methanol.internal.cache.CacheWritingPublisher.Listener
- discard(Executor) - Method in class com.github.mizosoft.methanol.internal.cache.NetworkResponse
-
Discards the response body in background.
- disk(Path, long) - Static method in interface com.github.mizosoft.methanol.StorageExtension
- DISK - Enum constant in enum class com.github.mizosoft.methanol.testing.store.StoreConfig.StoreType
- DiskStore - Class in com.github.mizosoft.methanol.internal.cache
-
A persistent
Store
implementation that saves entries on disk under a specified directory. - DiskStore.Builder - Class in com.github.mizosoft.methanol.internal.cache
- DiskStore.Hash - Class in com.github.mizosoft.methanol.internal.cache
-
An immutable 80-bit hash code.
- DiskStore.Hasher - Interface in com.github.mizosoft.methanol.internal.cache
-
A function that computes an 80-bit hash from a string key.
- DiskStoreConfig - Class in com.github.mizosoft.methanol.testing.store
- DiskStoreConfig(long, int, StoreConfig.FileSystemType, StoreConfig.Execution, int, boolean, boolean, boolean) - Constructor for class com.github.mizosoft.methanol.testing.store.DiskStoreConfig
- DiskStoreContext - Class in com.github.mizosoft.methanol.testing.store
- dispatchEagerly() - Method in class com.github.mizosoft.methanol.testing.store.DiskStoreConfig
- dispatchEagerly() - Element in annotation interface com.github.mizosoft.methanol.testing.store.StoreSpec
-
Whether
MockDelayer
should eagerly dispatch ready tasks (tasks whose delay is evaluated) whenever a task is submitted. - dispose() - Method in class com.github.mizosoft.methanol.HttpCache
-
Atomically clears and closes this cache.
- dispose() - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore
- dispose() - Method in class com.github.mizosoft.methanol.internal.cache.MemoryStore
- dispose() - Method in interface com.github.mizosoft.methanol.internal.cache.Store
-
Atomically clears and closes this store.
- doesNotContainHeader(String) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- doesNotContainRequestHeader(String) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- doesNotContainTag(Class<?>) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- doesNotSupport(TypeRef<?>) - Method in class com.github.mizosoft.methanol.testing.verifiers.BodyAdapterVerifier
- doesNotSupport(Class<?>) - Method in class com.github.mizosoft.methanol.testing.verifiers.BodyAdapterVerifier
- done() - Method in interface com.github.mizosoft.methanol.ProgressTracker.Progress
-
Returns
true
if the upload or download operation is done. - downstream() - Method in interface com.github.mizosoft.methanol.BodyDecoder
-
Returns this decoder's downstream.
- downstream() - Method in class com.github.mizosoft.methanol.decoder.AsyncBodyDecoder
- downstream() - Method in class com.github.mizosoft.methanol.internal.extensions.AsyncSubscriberAdapter
- downstream() - Method in class com.github.mizosoft.methanol.internal.extensions.ForwardingBodySubscriber
- downstream() - Method in class com.github.mizosoft.methanol.internal.flow.ForwardingSubscriber
-
Returns the downstream to which signals are forwarded.
- downstream() - Method in class com.github.mizosoft.methanol.internal.flow.TimeoutSubscriber
- drainQueuedTasks(boolean) - Method in class com.github.mizosoft.methanol.testing.MockDelayer
- dropBody() - Method in class com.github.mizosoft.methanol.ResponseBuilder
E
- edit() - Method in class com.github.mizosoft.methanol.internal.cache.CacheResponse
- edit() - Method in interface com.github.mizosoft.methanol.internal.cache.Store.Viewer
-
Synchronous variant of
Store.Viewer.edit(Executor)
. - edit(Store.Viewer) - Static method in class com.github.mizosoft.methanol.testing.store.StoreTesting
- edit(Store, String) - Static method in class com.github.mizosoft.methanol.testing.store.StoreTesting
- edit(String) - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore
- edit(String) - Method in class com.github.mizosoft.methanol.internal.cache.MemoryStore
- edit(String) - Method in interface com.github.mizosoft.methanol.internal.cache.Store
-
Synchronous variant of
Store.edit(String, Executor)
. - edit(String, Executor) - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore
- edit(String, Executor) - Method in class com.github.mizosoft.methanol.internal.cache.MemoryStore
- edit(String, Executor) - Method in interface com.github.mizosoft.methanol.internal.cache.Store
-
Opens an editor for the entry associated with the given key.
- edit(Executor) - Method in interface com.github.mizosoft.methanol.internal.cache.Store.Viewer
-
Opens an editor for the entry this viewer was opened for.
- editorLockInactiveTtlSeconds() - Method in class com.github.mizosoft.methanol.testing.store.RedisClusterStoreConfig
- editorLockInactiveTtlSeconds() - Method in class com.github.mizosoft.methanol.testing.store.RedisStandaloneStoreConfig
- editorLockInactiveTtlSeconds() - Element in annotation interface com.github.mizosoft.methanol.testing.store.StoreSpec
-
The number of seconds an inactive editor lock gets to live.
- editorLockInactiveTtlSeconds(int) - Method in class com.github.mizosoft.methanol.store.redis.RedisStorageExtension.Builder
-
Specifies the number of seconds an active entry editor (writer) remains valid.
- emit(Flow.Subscriber<? super T>, long) - Method in class com.github.mizosoft.methanol.internal.flow.AbstractPollableSubscription
- emit(Flow.Subscriber<? super T>, long) - Method in class com.github.mizosoft.methanol.internal.flow.AbstractSubscription
-
Emits at most
emit
items to downstream usingAbstractSubscription.submitOnNext(Subscriber, Object)
as long as it returnstrue
. - empty() - Static method in interface com.github.mizosoft.methanol.BodyAdapter.Hints
-
Returns a
Hints
object containing no hints. - empty() - Static method in class com.github.mizosoft.methanol.CacheControl
-
Returns a
CacheControl
with no directives. - empty() - Static method in interface com.github.mizosoft.methanol.HttpCache.Stats
-
Returns a
Stats
with zero counters. - EMPTY_BUFFER - Static variable in class com.github.mizosoft.methanol.testing.TestUtils
- emptyPublisher() - Static method in class com.github.mizosoft.methanol.internal.flow.FlowSupport
- EmptyPublisher<T> - Class in com.github.mizosoft.methanol.testing
-
A publisher that completes subscribers immediately.
- EMULATED_WINDOWS - Enum constant in enum class com.github.mizosoft.methanol.testing.store.StoreConfig.FileSystemType
- enclosedProgress() - Method in class com.github.mizosoft.methanol.ProgressTracker
-
Returns whether the sequence of progress events is enclosed between
0%
and100%
progress events. - enclosedProgress(boolean) - Method in class com.github.mizosoft.methanol.ProgressTracker.Builder
-
If set to
true
(default), the sequence of progress events will be enclosed between0%
and100%
progresses to detect begin and completion events respectively. - encode() - Method in class com.github.mizosoft.methanol.internal.cache.CacheResponseMetadata
- encodedString() - Method in class com.github.mizosoft.methanol.FormBodyPublisher
-
Returns the url-encoded string of this body's queries.
- encoder() - Static method in class com.github.mizosoft.methanol.internal.adapter.BasicAdapter
- encoder(BodyAdapter.Encoder) - Method in class com.github.mizosoft.methanol.AdapterCodec.Builder
-
Adds the given encoder.
- encoders() - Method in class com.github.mizosoft.methanol.AdapterCodec
-
Returns the list of encoders in this codec.
- EncoderVerifier - Class in com.github.mizosoft.methanol.testing.verifiers
-
A small DSL for testing
BodyAdapter.Encoder
implementations. - EncoderVerifier(BodyAdapter.Encoder) - Constructor for class com.github.mizosoft.methanol.testing.verifiers.EncoderVerifier
- EncoderVerifier.ObjectConversionStep<T> - Class in com.github.mizosoft.methanol.testing.verifiers
- encoding() - Method in interface com.github.mizosoft.methanol.BodyDecoder
-
Returns the encoding used by this decoder.
- encoding() - Method in interface com.github.mizosoft.methanol.BodyDecoder.Factory
-
Returns the encoding used by
BodyDecoders
created by this factory. - encoding() - Method in class com.github.mizosoft.methanol.brotli.internal.BrotliBodyDecoderFactory
- encoding() - Method in class com.github.mizosoft.methanol.decoder.AsyncBodyDecoder
- encoding() - Method in interface com.github.mizosoft.methanol.decoder.AsyncDecoder
-
Returns this decoder's encoding.
- encoding() - Method in class com.github.mizosoft.methanol.internal.decoder.DeflateBodyDecoderFactory
- encoding() - Method in class com.github.mizosoft.methanol.internal.decoder.GzipBodyDecoderFactory
- entriesOnUnderlyingStorageForTesting(String) - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore
- entriesOnUnderlyingStorageForTesting(String) - Method in interface com.github.mizosoft.methanol.internal.cache.TestableStore
-
Returns string representations for the resources an entry with the given key occupies on the underlying store.
- entrySize() - Method in interface com.github.mizosoft.methanol.internal.cache.Store.Viewer
-
Returns the size in bytes of the metadata block and data stream.
- equals(Object) - Method in class com.github.mizosoft.methanol.CacheControl
- equals(Object) - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore.Hash
- equals(Object) - Method in class com.github.mizosoft.methanol.MediaType
-
Tests the given object for equality with this instance.
- equals(Object) - Method in class com.github.mizosoft.methanol.TypeRef
-
Returns
true
if the given object is aTypeRef
and both instances represent the same type. - equals(Object) - Method in interface com.github.mizosoft.methanol.BodyAdapter.Hints
- errorCount() - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- escapeAndQuoteValueIfNeeded(String) - Static method in class com.github.mizosoft.methanol.internal.Utils
-
From RFC 7230 section 3.2.6:
- exactRawType() - Method in class com.github.mizosoft.methanol.TypeRef
-
Returns the underlying type as a
Class<T>
for when it is known thatTypeRef
is a raw type. - exchange(HttpRequest, HttpResponse.BodyHandler<T>) - Method in class com.github.mizosoft.methanol.Methanol
-
Returns a
Publisher
for theHttpResponse<T>
resulting from asynchronously sending the given request. - exchange(HttpRequest, HttpResponse.BodyHandler<T>, Function<HttpRequest, HttpResponse.BodyHandler<T>>) - Method in class com.github.mizosoft.methanol.Methanol
-
Returns a
Publisher
for the sequence ofHttpResponse<T>
resulting from asynchronously sending the given request along with accepting incomingpush promises
using the givenFunction
. - execute(Runnable) - Method in class com.github.mizosoft.methanol.internal.concurrent.SerialExecutor
- execute(Runnable) - Method in class com.github.mizosoft.methanol.testing.MockExecutor
- executeDirectly(boolean) - Method in class com.github.mizosoft.methanol.testing.MockExecutor
- execution() - Method in class com.github.mizosoft.methanol.testing.store.DiskStoreConfig
- execution() - Element in annotation interface com.github.mizosoft.methanol.testing.store.StoreSpec
- executor() - Method in interface com.github.mizosoft.methanol.BodyDecoder
-
Returns an
Optional
containing this decoder's executor. - executor() - Method in class com.github.mizosoft.methanol.decoder.AsyncBodyDecoder
- executor() - Method in class com.github.mizosoft.methanol.HttpCache
-
Returns an
Optional
containing this cache's executor if one is explicitly set. - executor() - Method in class com.github.mizosoft.methanol.Methanol
- executor() - Method in class com.github.mizosoft.methanol.ProgressTracker
-
Returns the optional executor on which
ProgressTracker.Listener
methods are called. - executor() - Method in class com.github.mizosoft.methanol.testing.HttpClientStub
- executor() - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient
- executor(Executor) - Method in class com.github.mizosoft.methanol.HttpCache.Builder
-
Sets the executor to be used by the cache.
- executor(Executor) - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore.Builder
- executor(Executor) - Method in class com.github.mizosoft.methanol.Methanol.Builder
- executor(Executor) - Method in class com.github.mizosoft.methanol.ProgressTracker.Builder
-
Sets the executor on which
ProgressTracker.Listener
methods are called. - ExecutorContext - Class in com.github.mizosoft.methanol.testing
-
Creates and manages
Executor
instances. - ExecutorContext() - Constructor for class com.github.mizosoft.methanol.testing.ExecutorContext
- ExecutorExtension - Class in com.github.mizosoft.methanol.testing
-
Extension
that providesExecutors
and terminates them after tests. - ExecutorExtension() - Constructor for class com.github.mizosoft.methanol.testing.ExecutorExtension
- ExecutorExtension.ExecutorParameterizedTest - Annotation Interface in com.github.mizosoft.methanol.testing
- ExecutorExtension.ExecutorSource - Annotation Interface in com.github.mizosoft.methanol.testing
- ExecutorExtension.ExecutorSpec - Annotation Interface in com.github.mizosoft.methanol.testing
- ExecutorExtension.ExecutorType - Enum Class in com.github.mizosoft.methanol.testing
- expectContinue() - Method in class com.github.mizosoft.methanol.MutableRequest
- expectContinue(boolean) - Method in class com.github.mizosoft.methanol.MutableRequest
- expectContinue(boolean) - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
F
- factories() - Static method in class com.github.mizosoft.methanol.internal.spi.BodyDecoderFactoryProviders
- FailingPublisher<T> - Class in com.github.mizosoft.methanol.testing
-
A publisher that fails immediately with a user-supplied error.
- FailingPublisher(Supplier<Throwable>) - Constructor for class com.github.mizosoft.methanol.testing.FailingPublisher
- failsWith(Class<? extends Throwable>) - Method in class com.github.mizosoft.methanol.testing.verifiers.BodyPublisherVerifier
- failsWith(Class<? extends Throwable>) - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.BodySubscriberVerifier
- failsWith(Class<? extends Throwable>) - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.SupplierVerifier
- failsWith(Class<? extends Throwable>) - Method in class com.github.mizosoft.methanol.testing.verifiers.EncoderVerifier.ObjectConversionStep
- FallbackExecutorProvider - Class in com.github.mizosoft.methanol.internal.concurrent
-
Provides an executor that is used across the library when no executor is supplied by the user.
- FIELD_VALUE_MATCHER - Static variable in class com.github.mizosoft.methanol.internal.text.HttpCharMatchers
- FileIO - Class in com.github.mizosoft.methanol.internal.cache
-
Read/Write utilities that make sure exactly the requested bytes are read/written.
- filePart(String, Path) - Method in class com.github.mizosoft.methanol.MultipartBodyPublisher.Builder
-
Adds a file form field with the given name and file.
- filePart(String, Path, MediaType) - Method in class com.github.mizosoft.methanol.MultipartBodyPublisher.Builder
-
Adds a file form field with given name, file and media type.
- fileSystem() - Element in annotation interface com.github.mizosoft.methanol.testing.store.StoreSpec
- fileSystemType() - Method in class com.github.mizosoft.methanol.testing.store.DiskStoreConfig
- finalSource() - Method in interface com.github.mizosoft.methanol.decoder.AsyncDecoder.ByteSource
-
Returns true if this source is final and no more decode operations are to be expected.
- findRepetitionCount(ExtensionContext) - Static method in class com.github.mizosoft.methanol.testing.RepeatArgumentsSupport
- fireOrKeepAlive() - Method in class com.github.mizosoft.methanol.internal.flow.AbstractSubscription
- fireOrKeepAliveOnError(Throwable) - Method in class com.github.mizosoft.methanol.internal.flow.AbstractSubscription
- fireOrKeepAliveOnNext() - Method in class com.github.mizosoft.methanol.internal.flow.AbstractSubscription
- firstQuery(String) - Method in class com.github.mizosoft.methanol.FormBodyPublisher
-
Returns the first value of the query associated with the given key.
- firstSubscription() - Method in class com.github.mizosoft.methanol.testing.SubmittablePublisher
- FLG - Enum constant in enum class com.github.mizosoft.methanol.testing.MockGzipStream.CorruptionMode
- flowInterrupted() - Method in class com.github.mizosoft.methanol.testing.SubmittableSubscription
- FlowSupport - Class in com.github.mizosoft.methanol.internal.flow
-
Helpers for implementing reactive streams subscriptions and the like.
- flush() - Method in class com.github.mizosoft.methanol.HttpCache
- flush() - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore
- flush() - Method in class com.github.mizosoft.methanol.internal.cache.MemoryStore
- flush() - Method in interface com.github.mizosoft.methanol.internal.cache.Store
-
Flushes any indexing data buffered by this store.
- flush() - Method in class com.github.mizosoft.methanol.WritableBodyPublisher
-
Makes any buffered content available for consumption by the downstream.
- followRedirects() - Method in class com.github.mizosoft.methanol.Methanol
- followRedirects() - Method in class com.github.mizosoft.methanol.testing.HttpClientStub
- followRedirects() - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient
- followRedirects(HttpClient.Redirect) - Method in class com.github.mizosoft.methanol.Methanol.Builder
- force(boolean) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingAsynchronousFileChannel
- force(boolean) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- forDecoder(HttpResponse.ResponseInfo) - Method in class com.github.mizosoft.methanol.BodyAdapter.Hints.Builder
-
Adds the given
ResponseInfo
as a hint and a media type hint extracted from the response headers if present. - forEach(Consumer<? super T>) - Method in class com.github.mizosoft.methanol.testing.CloseableCopyOnWriteList
- forEncoder(HttpRequest) - Method in class com.github.mizosoft.methanol.BodyAdapter.Hints.Builder
-
Adds the given request as a hint and a media type hint extracted from either the request's body or
Content-Type
header, whichever is present first. - formatHttpDate(LocalDateTime) - Static method in class com.github.mizosoft.methanol.internal.cache.HttpDates
- FormBodyPublisher - Class in com.github.mizosoft.methanol
-
A
BodyPublisher
for form submission using theapplication/x-www-form-urlencoded
request type. - FormBodyPublisher.Builder - Class in com.github.mizosoft.methanol
-
A builder of
FormBodyPublisher
instances. - formPart(String, String, HttpRequest.BodyPublisher) - Method in class com.github.mizosoft.methanol.MultipartBodyPublisher.Builder
-
Adds a form field with the given name, filename and body.
- formPart(String, String, HttpRequest.BodyPublisher, MediaType) - Method in class com.github.mizosoft.methanol.MultipartBodyPublisher.Builder
-
Adds a form field with the given name, filename, body and media type.
- formPart(String, HttpRequest.BodyPublisher) - Method in class com.github.mizosoft.methanol.MultipartBodyPublisher.Builder
-
Adds a form field with the given name and body.
- forward(HttpRequest) - Method in interface com.github.mizosoft.methanol.Methanol.Interceptor.Chain
-
Forwards the request to the next interceptor, or to the client's backend if called by the last interceptor.
- forwardAsync(HttpRequest) - Method in interface com.github.mizosoft.methanol.Methanol.Interceptor.Chain
-
Forwards the request to the next interceptor, or asynchronously to the client's backend if called by the last interceptor.
- ForwardingAsynchronousFileChannel - Class in com.github.mizosoft.methanol.testing.file
- ForwardingAsynchronousFileChannel(AsynchronousFileChannel) - Constructor for class com.github.mizosoft.methanol.testing.file.ForwardingAsynchronousFileChannel
- ForwardingBodyAdapter - Class in com.github.mizosoft.methanol.adapter
-
A
BodyAdapter
that forwards calls to another. - ForwardingBodyAdapter() - Constructor for class com.github.mizosoft.methanol.adapter.ForwardingBodyAdapter
- ForwardingBodyPublisher - Class in com.github.mizosoft.methanol.internal.extensions
- ForwardingBodyPublisher(HttpRequest.BodyPublisher) - Constructor for class com.github.mizosoft.methanol.internal.extensions.ForwardingBodyPublisher
- ForwardingBodySubscriber<T> - Class in com.github.mizosoft.methanol.internal.extensions
- ForwardingBodySubscriber(HttpResponse.BodySubscriber<T>) - Constructor for class com.github.mizosoft.methanol.internal.extensions.ForwardingBodySubscriber
- ForwardingDecoder - Class in com.github.mizosoft.methanol.adapter
-
A
BodyAdapter.Decoder
that forwards calls to another. - ForwardingDecoder(BodyAdapter.Decoder) - Constructor for class com.github.mizosoft.methanol.adapter.ForwardingDecoder
- ForwardingEncoder - Class in com.github.mizosoft.methanol.adapter
-
An
BodyAdapter.Encoder
that forwards calls to another. - ForwardingEncoder(BodyAdapter.Encoder) - Constructor for class com.github.mizosoft.methanol.adapter.ForwardingEncoder
- ForwardingFileChannel - Class in com.github.mizosoft.methanol.testing.file
- ForwardingFileChannel(FileChannel) - Constructor for class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- ForwardingObject - Interface in com.github.mizosoft.methanol.testing.file
-
An object that forwards calls to another and allows retrieving the delegate object.
- ForwardingSubscriber<T> - Class in com.github.mizosoft.methanol.internal.flow
-
A
Subscriber<T>
that forwards to a downstreamSubscriber<? super T>
. - ForwardingSubscriber() - Constructor for class com.github.mizosoft.methanol.internal.flow.ForwardingSubscriber
- from(TrackedResponse<?>) - Static method in class com.github.mizosoft.methanol.internal.cache.CacheResponseMetadata
- from(TrackedResponse<Flow.Publisher<List<ByteBuffer>>>) - Static method in class com.github.mizosoft.methanol.internal.cache.NetworkResponse
- from(Class<U>) - Static method in class com.github.mizosoft.methanol.TypeRef
-
Deprecated.in favor of
TypeRef.of(Class)
- from(Type) - Static method in class com.github.mizosoft.methanol.TypeRef
-
Deprecated.in favor of
TypeRef.of(Type)
. - from(HttpRequest) - Static method in class com.github.mizosoft.methanol.TaggableRequest
-
Returns either the given request if it's a
TaggableRequest
or a newTaggableRequest
copy with no tags otherwise. - from(HttpResponse<?>) - Static method in class com.github.mizosoft.methanol.internal.extensions.ImmutableResponseInfo
- fromAsyncSubscriber(S, Function<? super S, ? extends CompletionStage<T>>) - Static method in class com.github.mizosoft.methanol.MoreBodyHandlers
-
Returns a
BodyHandler
that returns a subscriber obtained fromMoreBodySubscribers.fromAsyncSubscriber(Subscriber, Function)
. - fromAsyncSubscriber(S, Function<? super S, ? extends CompletionStage<T>>) - Static method in class com.github.mizosoft.methanol.MoreBodySubscribers
-
Returns a
BodySubscriber
that forwards the response body to the given downstream. - func(ThrowingFunction<T, R>) - Static method in class com.github.mizosoft.methanol.internal.function.Unchecked
- future() - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient.Call
G
- get() - Method in class com.github.mizosoft.methanol.internal.adapter.PayloadHandlerExecutor
- get() - Method in class com.github.mizosoft.methanol.internal.cache.RawResponse
- get() - Static method in class com.github.mizosoft.methanol.internal.concurrent.FallbackExecutorProvider
- get() - Method in class com.github.mizosoft.methanol.internal.concurrent.Lazy
- get() - Method in class com.github.mizosoft.methanol.internal.flow.Upstream
- get() - Method in interface com.github.mizosoft.methanol.internal.function.ThrowingSupplier
- get() - Method in class com.github.mizosoft.methanol.internal.spi.ServiceProviders
- get() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- get(int) - Method in class com.github.mizosoft.methanol.testing.CloseableCopyOnWriteList
- get(Class<T>) - Method in interface com.github.mizosoft.methanol.BodyAdapter.Hints
-
Returns the hint mapped to by the given type.
- get(HttpRequest, Instant) - Method in interface com.github.mizosoft.methanol.internal.cache.LocalCache
- get(Future<T>) - Static method in class com.github.mizosoft.methanol.internal.Utils
- GET() - Method in class com.github.mizosoft.methanol.MutableRequest
- GET() - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
- GET(String) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a GET method. - GET(URI) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a GET method. - getAndAddDemand(Object, VarHandle, long) - Static method in class com.github.mizosoft.methanol.internal.flow.FlowSupport
-
Adds the given count to demand, making sure it doesn't exceed
Long.MAX_VALUE
. - getBody() - Method in interface com.github.mizosoft.methanol.BodyDecoder
-
Returns the body's
CompletionStage
. - getBody() - Method in class com.github.mizosoft.methanol.internal.extensions.AsyncSubscriberAdapter
- getBody() - Method in class com.github.mizosoft.methanol.internal.extensions.ByteChannelBodySubscriber
- getBody() - Method in class com.github.mizosoft.methanol.internal.extensions.ForwardingBodySubscriber
- getBody() - Method in class com.github.mizosoft.methanol.internal.extensions.PublisherBodySubscriber
- getBody() - Method in class com.github.mizosoft.methanol.internal.extensions.TimeoutBodySubscriber
- getCacheAwareResponse() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- getCause() - Method in exception class com.github.mizosoft.methanol.adapter.jaxb.jakarta.UncheckedJaxbException
- getCause() - Method in exception class com.github.mizosoft.methanol.adapter.jaxb.UncheckedJaxbException
- getCharacter() - Method in class com.github.mizosoft.methanol.internal.text.HeaderValueTokenizer
- getDecoder(TypeRef<?>, MediaType) - Static method in interface com.github.mizosoft.methanol.BodyAdapter.Decoder
-
Returns a decoder that supports the given object type and media type.
- getDeepCompletionCause(Throwable) - Static method in class com.github.mizosoft.methanol.internal.Utils
- getDefault() - Static method in interface com.github.mizosoft.methanol.adapter.jackson.ObjectReaderFactory
- getDefault() - Static method in interface com.github.mizosoft.methanol.adapter.jackson.ObjectWriterFactory
- getEncoder(TypeRef<?>, MediaType) - Static method in interface com.github.mizosoft.methanol.BodyAdapter.Encoder
-
Returns the encoder that supports the given object type and media type.
- getFactory(String) - Static method in interface com.github.mizosoft.methanol.BodyDecoder.Factory
-
Returns an
Optional
containing the factory registered for the given encoding. - getFileStores() - Method in class com.github.mizosoft.methanol.testing.file.LeakDetectingFileSystem
- getFileStores() - Method in class com.github.mizosoft.methanol.testing.file.WindowsEmulatingFileSystem
- getIo(Future<T>) - Static method in class com.github.mizosoft.methanol.internal.Utils
- getPath(String, String...) - Method in class com.github.mizosoft.methanol.testing.file.LeakDetectingFileSystem
- getPath(String, String...) - Method in class com.github.mizosoft.methanol.testing.file.WindowsEmulatingFileSystem
- getPathMatcher(String) - Method in class com.github.mizosoft.methanol.testing.file.LeakDetectingFileSystem
- getPathMatcher(String) - Method in class com.github.mizosoft.methanol.testing.file.WindowsEmulatingFileSystem
- getRootDirectories() - Method in class com.github.mizosoft.methanol.testing.file.LeakDetectingFileSystem
- getRootDirectories() - Method in class com.github.mizosoft.methanol.testing.file.WindowsEmulatingFileSystem
- getSeparator() - Method in class com.github.mizosoft.methanol.testing.file.LeakDetectingFileSystem
- getSeparator() - Method in class com.github.mizosoft.methanol.testing.file.WindowsEmulatingFileSystem
- getTrackedResponse() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- getUserPrincipalLookupService() - Method in class com.github.mizosoft.methanol.testing.file.LeakDetectingFileSystem
- getUserPrincipalLookupService() - Method in class com.github.mizosoft.methanol.testing.file.WindowsEmulatingFileSystem
- getZone() - Method in class com.github.mizosoft.methanol.testing.MockClock
- GsonAdapterFactory - Class in com.github.mizosoft.methanol.adapter.gson
-
Provides
BodyAdapter
implementations for JSON using the Gson library. - guarded() - Method in interface com.github.mizosoft.methanol.internal.cache.CacheReadingPublisher.Listener
- guarded() - Method in interface com.github.mizosoft.methanol.internal.cache.CacheWritingPublisher.Listener
- gunzip(byte[]) - Static method in class com.github.mizosoft.methanol.testing.TestUtils
- gzip(String) - Static method in class com.github.mizosoft.methanol.testing.TestUtils
- GzipBodyDecoderFactory - Class in com.github.mizosoft.methanol.internal.decoder
-
BodyDecoder.Factory
for "gzip". - GzipBodyDecoderFactory() - Constructor for class com.github.mizosoft.methanol.internal.decoder.GzipBodyDecoderFactory
-
Creates a new
GzipBodyDecoderFactory
.
H
- handle(HttpResponse.BodyHandler<T>) - Method in class com.github.mizosoft.methanol.internal.cache.RawResponse
- handleAsync(HttpResponse.BodyHandler<T>, Executor) - Method in class com.github.mizosoft.methanol.internal.cache.CacheResponse
- handleAsync(HttpResponse.BodyHandler<T>, Executor) - Method in class com.github.mizosoft.methanol.internal.cache.NetworkResponse
- handleAsync(HttpResponse.BodyHandler<T>, Executor) - Method in class com.github.mizosoft.methanol.internal.cache.RawResponse
- handleAsync(HttpResponse.ResponseInfo, Flow.Publisher<List<ByteBuffer>>, HttpResponse.BodyHandler<T>, Executor) - Static method in class com.github.mizosoft.methanol.internal.extensions.Handlers
- handleAsync(HttpResponse<?>, Flow.Publisher<List<ByteBuffer>>, HttpResponse.BodyHandler<T>, Executor) - Static method in class com.github.mizosoft.methanol.internal.extensions.Handlers
- handleAsync(HttpResponse<Flow.Publisher<List<ByteBuffer>>>, HttpResponse.BodyHandler<T>, Executor) - Static method in class com.github.mizosoft.methanol.internal.extensions.Handlers
- handleCalls(Consumer<RecordingHttpClient.Call<?>>) - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient
- handlerOf(TypeRef<T>, BodyAdapter.Hints) - Method in class com.github.mizosoft.methanol.AdapterCodec
-
Returns a
HttpResponse.BodyHandler
that decodes the response body into an object of the given type. - Handlers - Class in com.github.mizosoft.methanol.internal.extensions
-
Static functions for converting the response body into a usable body type.
- handleWith(HttpResponse.BodyHandler<T>) - Method in interface com.github.mizosoft.methanol.ResponsePayload
-
Converts this payload using the given body handler.
- handleWithAsync(HttpResponse.BodyHandler<T>) - Method in interface com.github.mizosoft.methanol.ResponsePayload
-
Asynchronously converts this payload using the given body handler.
- hasBody(T) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- hasBodyPublisher(HttpRequest.BodyPublisher) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- hasBodyPublisher(Optional<HttpRequest.BodyPublisher>) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- hasCacheResponse() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- hasCacheStatus(CacheAwareResponse.CacheStatus) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- hasCode(int) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- hasContentLength(long) - Method in class com.github.mizosoft.methanol.testing.verifiers.BodyPublisherVerifier
- hasEmptyHeaders() - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- hasExpectContinue(boolean) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- hash(String) - Method in interface com.github.mizosoft.methanol.internal.cache.DiskStore.Hasher
- hash(String) - Method in class com.github.mizosoft.methanol.testing.store.MockHasher
- Hash(ByteBuffer) - Constructor for class com.github.mizosoft.methanol.internal.cache.DiskStore.Hash
- hashCode() - Method in interface com.github.mizosoft.methanol.BodyAdapter.Hints
- hashCode() - Method in class com.github.mizosoft.methanol.CacheControl
- hashCode() - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore.Hash
- hashCode() - Method in class com.github.mizosoft.methanol.MediaType
-
Returns a hashcode for this media type.
- hashCode() - Method in class com.github.mizosoft.methanol.TypeRef
- hasher() - Method in class com.github.mizosoft.methanol.testing.store.DiskStoreContext
- hasher(DiskStore.Hasher) - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore.Builder
- hasMediaType(MediaType) - Method in class com.github.mizosoft.methanol.testing.verifiers.BodyPublisherVerifier
- hasMediaType(String) - Method in class com.github.mizosoft.methanol.testing.verifiers.BodyPublisherVerifier
- hasMethod(String) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- hasNetworkResponse() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- hasNext() - Method in class com.github.mizosoft.methanol.testing.ByteBufferIterator
- hasNext() - Method in class com.github.mizosoft.methanol.testing.ByteBufferListIterator
- hasNext() - Method in class com.github.mizosoft.methanol.testing.MockExecutor
- hasNoBody() - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- hasNoBody() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- hasNoCacheResponse() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- hasNoMediaType() - Method in class com.github.mizosoft.methanol.testing.verifiers.BodyPublisherVerifier
- hasNoNetworkResponse() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- hasNoTimeout() - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- hasNoVersion() - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- hasPendingErrors() - Method in class com.github.mizosoft.methanol.internal.flow.AbstractSubscription
-
Returns
true
if the subscriber is to be completed exceptionally. - hasPreviousResponse() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- hasRemaining() - Method in interface com.github.mizosoft.methanol.decoder.AsyncDecoder.ByteSource
-
Returns
true
if this source has remaining bytes. - hasRemaining() - Method in class com.github.mizosoft.methanol.internal.text.HeaderValueTokenizer
- hasSslSession(Optional<SSLSession>) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- hasSslSession(SSLSession) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- hasTimeout(Duration) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- hasTimeout(Optional<Duration>) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- hasUri(String) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- hasUri(URI) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- hasUri(URI) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- hasVersion(HttpClient.Version) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- hasVersion(Optional<HttpClient.Version>) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- hasWildcard() - Method in class com.github.mizosoft.methanol.MediaType
-
Return
true
if this media type is*
/*
or if it has a wildcard subtype. - header(String, String) - Method in interface com.github.mizosoft.methanol.HeadersAccumulator
-
Adds the given header name-value pair.
- header(String, String) - Method in class com.github.mizosoft.methanol.MutableRequest
- header(String, String) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- header(String, String) - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
- headers() - Method in class com.github.mizosoft.methanol.internal.extensions.ImmutableResponseInfo
- headers() - Method in class com.github.mizosoft.methanol.MultipartBodyPublisher.Part
-
Returns this part's headers.
- headers() - Method in class com.github.mizosoft.methanol.MutableRequest
- headers() - Method in class com.github.mizosoft.methanol.testing.HttpResponseStub
- headers() - Method in class com.github.mizosoft.methanol.testing.ImmutableResponseInfo
- headers(String...) - Method in interface com.github.mizosoft.methanol.HeadersAccumulator
-
Adds each of the given header name-value pairs.
- headers(String...) - Method in class com.github.mizosoft.methanol.MutableRequest
- headers(String...) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- headers(String...) - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
- headers(String...) - Static method in class com.github.mizosoft.methanol.testing.TestUtils
- headers(HttpHeaders) - Method in interface com.github.mizosoft.methanol.HeadersAccumulator
-
Adds all the given headers.
- headers(HttpHeaders) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Adds each of the given
HttpHeaders
. - headers(HttpHeaders) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- HeadersAccumulator<T> - Interface in com.github.mizosoft.methanol
-
An accumulator of header name-value pairs.
- HeadersBuilder - Class in com.github.mizosoft.methanol.internal.extensions
- HeadersBuilder() - Constructor for class com.github.mizosoft.methanol.internal.extensions.HeadersBuilder
- headersTimeout() - Method in class com.github.mizosoft.methanol.Methanol
-
Returns the headers timeout.
- headersTimeout(Duration) - Method in class com.github.mizosoft.methanol.Methanol.BaseBuilder
-
Sets a timeout that will raise an
HttpHeadersTimeoutException
if all response headers aren't received within the timeout. - headersTimeout(Duration, ScheduledExecutorService) - Method in class com.github.mizosoft.methanol.Methanol.BaseBuilder
-
Same as
Methanol.BaseBuilder.headersTimeout(Duration)
but specifies aScheduledExecutorService
to use for scheduling timeout events. - HeaderValueTokenizer - Class in com.github.mizosoft.methanol.internal.text
-
Tokenizes delimited header values into individual components.
- HeaderValueTokenizer(String) - Constructor for class com.github.mizosoft.methanol.internal.text.HeaderValueTokenizer
- hint(Class<T>, T) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Adds the given value to this request's
BodyAdapter.Hints
. - hints() - Method in class com.github.mizosoft.methanol.MutableRequest
- hints() - Method in class com.github.mizosoft.methanol.TaggableRequest
-
Returns this request's
BodyAdapter.Hints
. - hints(Consumer<BodyAdapter.Hints.Builder>) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Modifies this request's
BodyAdapter.Hints
by mutating aBodyAdapter.Hints.Builder
. - hintsOf(MediaType) - Static method in class com.github.mizosoft.methanol.internal.Utils
- HIT - Enum constant in enum class com.github.mizosoft.methanol.CacheAwareResponse.CacheStatus
-
The response was entirely constructed from cache and no network was used.
- hitCount() - Method in interface com.github.mizosoft.methanol.HttpCache.Stats
-
Returns the number of requests resulting in a cache hit, including conditional hits.
- hitRate() - Method in interface com.github.mizosoft.methanol.HttpCache.Stats
-
Returns a value between
0.0
and1.0
representing the ratio between the hit and request counts. - HttpCache - Class in com.github.mizosoft.methanol
- HttpCache.Builder - Class in com.github.mizosoft.methanol
-
A builder of
HttpCaches
. - HttpCache.Listener - Interface in com.github.mizosoft.methanol
-
A listener to request/response & read/write events within the cache.
- HttpCache.Stats - Interface in com.github.mizosoft.methanol
-
Statistics of an
HttpCache
. - HttpCache.StatsRecorder - Interface in com.github.mizosoft.methanol
-
Strategy for recoding
HttpCache
statistics. - HttpCharMatchers - Class in com.github.mizosoft.methanol.internal.text
-
Common
CharMatchers
for HTTP headers and the like. - HttpClientStub - Class in com.github.mizosoft.methanol.testing
- HttpClientStub() - Constructor for class com.github.mizosoft.methanol.testing.HttpClientStub
- HttpDates - Class in com.github.mizosoft.methanol.internal.cache
-
Helpers for parsing/formatting HTTP dates.
- HttpHeadersTimeoutException - Exception Class in com.github.mizosoft.methanol
-
Thrown when all response headers aren't received within a timeout.
- HttpHeadersTimeoutException(String) - Constructor for exception class com.github.mizosoft.methanol.HttpHeadersTimeoutException
-
Creates a new
HttpHeadersTimeoutException
with the given message. - HttpReadTimeoutException - Exception Class in com.github.mizosoft.methanol
-
Thrown when a body subscriber doesn't receive a requested signal within a timeout.
- HttpReadTimeoutException(String) - Constructor for exception class com.github.mizosoft.methanol.HttpReadTimeoutException
-
Creates a new
HttpReadTimeoutException
. - HttpResponsePublisher<T> - Class in com.github.mizosoft.methanol.internal.extensions
-
A publisher of
responses
resulting from sending a given request and optionally accepting incoming push promises, if any. - HttpResponsePublisher(HttpClient, HttpRequest, HttpResponse.BodyHandler<T>, Function<HttpRequest, HttpResponse.BodyHandler<T>>, Executor) - Constructor for class com.github.mizosoft.methanol.internal.extensions.HttpResponsePublisher
-
Creates a new
HttpResponsePublisher
. - HttpResponseStub<T> - Class in com.github.mizosoft.methanol.testing
- HttpResponseStub() - Constructor for class com.github.mizosoft.methanol.testing.HttpResponseStub
- HttpStatus - Class in com.github.mizosoft.methanol
-
Static functions for checking response status codes.
I
- illegalRequest() - Static method in class com.github.mizosoft.methanol.internal.flow.FlowSupport
-
Returns an
IllegalArgumentException
to signal if the subscriber requests a non-positive number of items. - IMAGE_ANY - Static variable in class com.github.mizosoft.methanol.MediaType
-
image
/*
- IMAGE_GIF - Static variable in class com.github.mizosoft.methanol.MediaType
-
image/gif
- IMAGE_JPEG - Static variable in class com.github.mizosoft.methanol.MediaType
-
image/jpeg
- IMAGE_PNG - Static variable in class com.github.mizosoft.methanol.MediaType
-
image/png
- ImmutableResponseInfo - Class in com.github.mizosoft.methanol.internal.extensions
-
Implementation of
ResponseInfo
. - ImmutableResponseInfo - Class in com.github.mizosoft.methanol.testing
- ImmutableResponseInfo() - Constructor for class com.github.mizosoft.methanol.testing.ImmutableResponseInfo
- ImmutableResponseInfo(int, HttpHeaders, HttpClient.Version) - Constructor for class com.github.mizosoft.methanol.internal.extensions.ImmutableResponseInfo
- ImmutableResponseInfo(int, HttpHeaders, HttpClient.Version) - Constructor for class com.github.mizosoft.methanol.testing.ImmutableResponseInfo
- implCloseChannel() - Method in class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- IN_MANY_OUT_MANY - Enum constant in enum class com.github.mizosoft.methanol.testing.decoder.Decode.BufferSizeOption
- IN_MANY_OUT_ONE - Enum constant in enum class com.github.mizosoft.methanol.testing.decoder.Decode.BufferSizeOption
- IN_MEMORY - Enum constant in enum class com.github.mizosoft.methanol.testing.store.StoreConfig.FileSystemType
- IN_ONE_OUT_MANY - Enum constant in enum class com.github.mizosoft.methanol.testing.decoder.Decode.BufferSizeOption
- IN_ONE_OUT_ONE - Enum constant in enum class com.github.mizosoft.methanol.testing.decoder.Decode.BufferSizeOption
- inception() - Method in class com.github.mizosoft.methanol.testing.MockClock
- includes(MediaType) - Method in class com.github.mizosoft.methanol.MediaType
-
Returns whether this media type includes the given one.
- indexUpdateDelay(Duration) - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore.Builder
- indexUpdateDelaySeconds() - Method in class com.github.mizosoft.methanol.testing.store.DiskStoreConfig
- indexUpdateDelaySeconds() - Element in annotation interface com.github.mizosoft.methanol.testing.store.StoreSpec
-
Delay between automatic index updates done by the disk store.
- inflate(byte[]) - Static method in class com.github.mizosoft.methanol.testing.TestUtils
- initialize() - Method in class com.github.mizosoft.methanol.HttpCache
-
Deprecated, for removal: This API element is subject to removal in a future version.As of
1.8.0
, a cache is always initialized when created. For background initialization, please useHttpCache.Builder.buildAsync()
. - initialize(Upstream) - Method in class com.github.mizosoft.methanol.internal.flow.Prefetcher
- initializeAsync() - Method in class com.github.mizosoft.methanol.HttpCache
-
Deprecated, for removal: This API element is subject to removal in a future version.As of
1.8.0
, a cache is always initialized when created. For background initialization, please useHttpCache.Builder.buildAsync()
. - inOptions() - Static method in enum class com.github.mizosoft.methanol.testing.decoder.Decode.BufferSizeOption
- inputReaderOf(Process) - Static method in class com.github.mizosoft.methanol.testing.TestUtils
- installed() - Static method in class com.github.mizosoft.methanol.AdapterCodec
- installed() - Static method in interface com.github.mizosoft.methanol.BodyAdapter.Decoder
-
Returns an immutable list containing the installed decoders.
- installed() - Static method in interface com.github.mizosoft.methanol.BodyAdapter.Encoder
-
Returns an immutable list containing the installed encoders.
- installed() - Static method in interface com.github.mizosoft.methanol.testing.MemoryFileSystemProvider
- installedBindings() - Static method in interface com.github.mizosoft.methanol.BodyDecoder.Factory
-
Returns an immutable map that case-insensitively maps encodings to their corresponding registered factories.
- installedFactories() - Static method in interface com.github.mizosoft.methanol.BodyDecoder.Factory
-
Returns an immutable list of the registered factories.
- instance() - Static method in class com.github.mizosoft.methanol.testing.EmptyPublisher
- instance(Executor) - Method in interface com.github.mizosoft.methanol.internal.cache.LocalCache.Factory
- instant() - Method in class com.github.mizosoft.methanol.testing.MockClock
- intercept(HttpRequest, Methanol.Interceptor.Chain<T>) - Method in class com.github.mizosoft.methanol.internal.cache.CacheInterceptor
- intercept(HttpRequest, Methanol.Interceptor.Chain<T>) - Method in class com.github.mizosoft.methanol.internal.cache.RedirectingInterceptor
- intercept(HttpRequest, Methanol.Interceptor.Chain<T>) - Method in interface com.github.mizosoft.methanol.Methanol.Interceptor
-
Intercepts given request and returns the resulting response, usually by forwarding to the given chain.
- interceptAsync(HttpRequest, Methanol.Interceptor.Chain<T>) - Method in class com.github.mizosoft.methanol.internal.cache.CacheInterceptor
- interceptAsync(HttpRequest, Methanol.Interceptor.Chain<T>) - Method in class com.github.mizosoft.methanol.internal.cache.RedirectingInterceptor
- interceptAsync(HttpRequest, Methanol.Interceptor.Chain<T>) - Method in interface com.github.mizosoft.methanol.Methanol.Interceptor
-
Intercepts the given request and returns a
CompletableFuture
for the resulting response, usually by forwarding to the given chain. - interceptor(Methanol.Interceptor) - Method in class com.github.mizosoft.methanol.Methanol.BaseBuilder
-
Adds an interceptor that is invoked right after the client receives a request.
- interceptors() - Method in class com.github.mizosoft.methanol.Methanol
-
Returns an immutable list of this client's
interceptors
. - InternalStorageExtension - Interface in com.github.mizosoft.methanol.internal.cache
- is(int) - Static method in interface com.github.mizosoft.methanol.internal.text.CharMatcher
- isAssertionsEnabled() - Static method in class com.github.mizosoft.methanol.internal.DebugUtils
- isAvailable() - Static method in class com.github.mizosoft.methanol.testing.store.RedisClusterStoreContext
- isAvailable() - Static method in class com.github.mizosoft.methanol.testing.store.RedisStandaloneStoreContext
- isCachedWithSsl() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- isCacheHit() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- isCacheMiss() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- isCacheMissWithCacheResponse() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- isCacheUnsatisfaction() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- isCancelled() - Method in class com.github.mizosoft.methanol.internal.flow.AbstractSubscription
-
Returns
true
if this subscription is cancelled. - isCancelled() - Method in class com.github.mizosoft.methanol.internal.flow.Upstream
- isCancelled() - Method in class com.github.mizosoft.methanol.testing.TestSubscription
- isClientError(int) - Static method in class com.github.mizosoft.methanol.HttpStatus
-
Returns
true
ifstatusCode
is a 4xx client error status code. - isClientError(HttpResponse<?>) - Static method in class com.github.mizosoft.methanol.HttpStatus
-
Returns
true
ifresponse.statusCode()
is a 4xx client error status code. - isClosed() - Method in class com.github.mizosoft.methanol.WritableBodyPublisher
-
Returns
true
if this publisher is closed by eitherclose()
orcloseExceptionally(java.lang.Throwable)
. - isCompatibleWith(MediaType) - Method in class com.github.mizosoft.methanol.adapter.AbstractBodyAdapter
- isCompatibleWith(MediaType) - Method in class com.github.mizosoft.methanol.adapter.ForwardingBodyAdapter
- isCompatibleWith(MediaType) - Method in interface com.github.mizosoft.methanol.BodyAdapter
-
Returns
true
if the format this adapter uses iscompatible
with the given media type. - isCompatibleWith(MediaType) - Method in class com.github.mizosoft.methanol.MediaType
-
Returns whether this media type is compatible with the given one.
- isCompatibleWith(MediaType) - Method in class com.github.mizosoft.methanol.testing.verifiers.BodyAdapterVerifier
- isCompatibleWith(String) - Method in class com.github.mizosoft.methanol.testing.verifiers.BodyAdapterVerifier
- isComplete() - Method in class com.github.mizosoft.methanol.internal.flow.AbstractPollableSubscription
-
Returns
true
if downstream is to be completed. - isComplete() - Method in class com.github.mizosoft.methanol.internal.flow.AbstractQueueSubscription
- isConditionalHit() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- isConditionalMiss() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- isDeeplyEqualTo(HttpRequest) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- isDELETE() - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- isEqualTo(HttpRequest) - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- isExternallyConditionalCacheHit() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
-
Tests if this is a conditional cache hit resulting from a request that is conditionalized by the client and evaluated by the cache, rather than conditionalized by the cache and evaluated by the origin.
- isGenericArray() - Method in class com.github.mizosoft.methanol.TypeRef
- isGET() - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- isHealthy() - Method in class com.github.mizosoft.methanol.testing.store.RedisClusterSession
- isHealthy() - Method in interface com.github.mizosoft.methanol.testing.store.RedisSession
-
Returns
true
if this session is operable. - isHealthy() - Method in class com.github.mizosoft.methanol.testing.store.RedisStandaloneSession
- isHttpDate(String) - Static method in class com.github.mizosoft.methanol.internal.cache.HttpDates
- isInformational(int) - Static method in class com.github.mizosoft.methanol.HttpStatus
-
Returns
true
ifstatusCode
is a 1xx informational status code. - isInformational(HttpResponse<?>) - Static method in class com.github.mizosoft.methanol.HttpStatus
-
Returns
true
ifresponse.statusCode()
is a 1xx informational status code. - ISIZE - Enum constant in enum class com.github.mizosoft.methanol.testing.MockGzipStream.CorruptionMode
- isNotCompatibleWith(MediaType) - Method in class com.github.mizosoft.methanol.testing.verifiers.BodyAdapterVerifier
- isNotCompatibleWith(String) - Method in class com.github.mizosoft.methanol.testing.verifiers.BodyAdapterVerifier
- isNotSecure() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- isNotSupported() - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.BodyConversionStep
- isNotSupported() - Method in class com.github.mizosoft.methanol.testing.verifiers.EncoderVerifier.ObjectConversionStep
- isOpen() - Method in class com.github.mizosoft.methanol.testing.file.ForwardingAsynchronousFileChannel
- isOpen() - Method in class com.github.mizosoft.methanol.testing.file.LeakDetectingFileSystem
- isOpen() - Method in class com.github.mizosoft.methanol.testing.file.WindowsEmulatingFileSystem
- isParameterizedType() - Method in class com.github.mizosoft.methanol.TypeRef
- isPATCH() - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- isPOST() - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- isPrivate() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns
true
if theprivate
directive is set. - isPublic() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns
true
if thepublic
directive is set. - isPUT() - Method in class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- isRawType() - Method in class com.github.mizosoft.methanol.TypeRef
-
Returns
true
ifTypeRef
is a raw type (i.e. - isReadOnly() - Method in class com.github.mizosoft.methanol.testing.file.LeakDetectingFileSystem
- isReadOnly() - Method in class com.github.mizosoft.methanol.testing.file.WindowsEmulatingFileSystem
- isRedirection(int) - Static method in class com.github.mizosoft.methanol.HttpStatus
-
Returns
true
ifstatusCode
is a 3xx redirection status code. - isRedirection(HttpResponse<?>) - Static method in class com.github.mizosoft.methanol.HttpStatus
-
Returns
true
ifresponse.statusCode()
is a 3xx redirection status code. - isSecure() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- isServable() - Method in class com.github.mizosoft.methanol.internal.cache.CacheResponse
- isServableOnError() - Method in class com.github.mizosoft.methanol.internal.cache.CacheResponse
- isServableWhileRevalidating() - Method in class com.github.mizosoft.methanol.internal.cache.CacheResponse
- isServerError(int) - Static method in class com.github.mizosoft.methanol.HttpStatus
-
Returns
true
ifstatusCode
is a 5xx server error status code. - isServerError(HttpResponse<?>) - Static method in class com.github.mizosoft.methanol.HttpStatus
-
Returns
true
ifresponse.statusCode()
is a 5xx server error status code. - isSet() - Method in class com.github.mizosoft.methanol.internal.flow.Upstream
-
Returns
true
if the subscription wasset
. - isSuccessful(int) - Static method in class com.github.mizosoft.methanol.HttpStatus
-
Returns
true
ifstatusCode
is a 2xx successful status code. - isSuccessful(HttpResponse<?>) - Static method in class com.github.mizosoft.methanol.HttpStatus
-
Returns
true
ifresponse.statusCode()
is a 2xx successful status code. - isTypeVariable() - Method in class com.github.mizosoft.methanol.TypeRef
- isValidHeaderName(String) - Static method in class com.github.mizosoft.methanol.internal.Utils
- isValidToken(CharSequence) - Static method in class com.github.mizosoft.methanol.internal.Utils
- isWildcard() - Method in class com.github.mizosoft.methanol.TypeRef
- IterablePublisher<T> - Class in com.github.mizosoft.methanol.testing
-
A publisher of items obtained from an
Iterable<T>
. - IterablePublisher(Iterable<T>, Executor) - Constructor for class com.github.mizosoft.methanol.testing.IterablePublisher
- iterator() - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore
- iterator() - Method in class com.github.mizosoft.methanol.internal.cache.MemoryStore
- iterator() - Method in interface com.github.mizosoft.methanol.internal.cache.Store
-
Returns an iterator of
Viewers
over the entries in this store. - iterator() - Method in class com.github.mizosoft.methanol.testing.CloseableCopyOnWriteList
- Iterators - Class in com.github.mizosoft.methanol.testing.file
J
- JacksonAdapterFactory - Class in com.github.mizosoft.methanol.adapter.jackson
-
Provides
BodyAdapter
implementations for JSON using the Jackson library. - JacksonFluxAdapterFactory - Class in com.github.mizosoft.methanol.adapter.jackson.flux
-
Provides
BodyAdapter
implementations for the JSON format using Jackson. - JavadocPlaceholder - Class in com.github.mizosoft.methanol.adapter.moshi
- JavadocPlaceholder - Class in com.github.mizosoft.methanol.kotlin
- JaxbAdapterFactory - Class in com.github.mizosoft.methanol.adapter.jaxb.jakarta
-
Creates
BodyAdapter
implementations for XML using JAXB. - JaxbAdapterFactory - Class in com.github.mizosoft.methanol.adapter.jaxb
-
Creates
BodyAdapter
implementations for XML using JAXB. - JaxbBindingFactory - Interface in com.github.mizosoft.methanol.adapter.jaxb.jakarta
-
Creates new
Marshaller
orUnmarshaller
objects on demand for use by an adapter. - JaxbBindingFactory - Interface in com.github.mizosoft.methanol.adapter.jaxb
-
Creates new
Marshaller
orUnmarshaller
objects on demand for use by an adapter.
K
- key() - Method in interface com.github.mizosoft.methanol.internal.cache.Store.Editor
-
Returns the entry's key.
- key() - Method in interface com.github.mizosoft.methanol.internal.cache.Store.Viewer
-
Returns the entry's key.
L
- lastCall() - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient
- lastQuery(String) - Method in class com.github.mizosoft.methanol.FormBodyPublisher
-
Returns the last value of the query associated with the given key.
- lastValue(String) - Method in class com.github.mizosoft.methanol.internal.extensions.HeadersBuilder
- Lazy<T> - Class in com.github.mizosoft.methanol.internal.concurrent
- LeakDetectingFileSystem - Class in com.github.mizosoft.methanol.testing.file
-
A
ForwardingFileSystem
that detects unclosed resources when closed. - letters() - Static method in interface com.github.mizosoft.methanol.internal.text.CharMatcher
- lettersOrDigits() - Static method in interface com.github.mizosoft.methanol.internal.text.CharMatcher
- lines(String) - Static method in class com.github.mizosoft.methanol.testing.TestUtils
- listener() - Method in class com.github.mizosoft.methanol.HttpCache
-
Returns the
HttpCache.Listener
set by the user. - listener(HttpCache.Listener) - Method in class com.github.mizosoft.methanol.HttpCache.Builder
-
Sets the cache's
Listener
. - listFiles(Path) - Static method in class com.github.mizosoft.methanol.testing.TestUtils
- load(Class<?>, String) - Static method in class com.github.mizosoft.methanol.testing.TestUtils
- loadUtf8(Class<?>, String) - Static method in class com.github.mizosoft.methanol.testing.TestUtils
- LocalCache - Interface in com.github.mizosoft.methanol.internal.cache
-
A response cache that provides APIs for retrieval, metadata updates, insertion and removal.
- LocalCache.Factory - Interface in com.github.mizosoft.methanol.internal.cache
- localhostCert() - Static method in class com.github.mizosoft.methanol.testing.TestUtils
- localhostSslContext() - Static method in class com.github.mizosoft.methanol.testing.TestUtils
-
Build
SSLContext
that trusts a self-assigned certificate for the loopback address. - lock(long, long, boolean) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingAsynchronousFileChannel
- lock(long, long, boolean) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- lock(long, long, boolean, A, CompletionHandler<FileLock, ? super A>) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingAsynchronousFileChannel
- logFiles() - Method in class com.github.mizosoft.methanol.testing.store.RedisClusterSession
- logFiles() - Method in interface com.github.mizosoft.methanol.testing.store.RedisSession
-
Returns the log files attached to this session.
- logFiles() - Method in class com.github.mizosoft.methanol.testing.store.RedisStandaloneSession
- Logging - Class in com.github.mizosoft.methanol.testing
-
Utility methods related to logging during tests.
M
- MAGIC - Enum constant in enum class com.github.mizosoft.methanol.testing.MockGzipStream.CorruptionMode
- map(FileChannel.MapMode, long, long) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- matches(char) - Method in interface com.github.mizosoft.methanol.internal.text.CharMatcher
- matches(HttpRequest) - Method in class com.github.mizosoft.methanol.internal.cache.CacheResponseMetadata
- max(T, T) - Static method in class com.github.mizosoft.methanol.internal.util.Compare
- maxAge() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns the value of the
max-age
directive if present. - maxAge(Duration) - Method in class com.github.mizosoft.methanol.CacheControl.Builder
-
Sets the
max-age
directive to the given duration. - maxSize() - Method in class com.github.mizosoft.methanol.HttpCache
-
Returns this cache's max size in bytes.
- maxSize() - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore
- maxSize() - Method in class com.github.mizosoft.methanol.internal.cache.MemoryStore
- maxSize() - Method in interface com.github.mizosoft.methanol.internal.cache.Store
-
Returns this store's max size in bytes.
- maxSize() - Method in class com.github.mizosoft.methanol.testing.store.StoreConfig
- maxSize() - Element in annotation interface com.github.mizosoft.methanol.testing.store.StoreSpec
- maxSize(long) - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore.Builder
- maxStale() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns the value of the
max-stale
directive if present. - maxStale(Duration) - Method in class com.github.mizosoft.methanol.CacheControl.Builder
-
Sets the
max-stale
directive to the given duration. - mediaType() - Method in interface com.github.mizosoft.methanol.BodyAdapter.Hints
-
Returns the
MediaType
hint. - mediaType() - Method in class com.github.mizosoft.methanol.FormBodyPublisher
- mediaType() - Method in class com.github.mizosoft.methanol.internal.extensions.MimeBodyPublisherAdapter
- mediaType() - Method in interface com.github.mizosoft.methanol.MimeBodyPublisher
-
Returns the body's media type.
- mediaType() - Method in class com.github.mizosoft.methanol.MultipartBodyPublisher
- mediaType(MediaType) - Method in class com.github.mizosoft.methanol.MultipartBodyPublisher.Builder
-
Sets the media type of the multipart body.
- MediaType - Class in com.github.mizosoft.methanol
-
A MIME type.
- mediaTypeOrAny() - Method in interface com.github.mizosoft.methanol.BodyAdapter.Hints
-
Returns either the
MediaType
hint orMediaType.ANY
if absent. - memory(long) - Static method in interface com.github.mizosoft.methanol.StorageExtension
- MEMORY - Enum constant in enum class com.github.mizosoft.methanol.testing.store.StoreConfig.StoreType
- MemoryFileSystemProvider - Interface in com.github.mizosoft.methanol.testing
- MemoryStore - Class in com.github.mizosoft.methanol.internal.cache
-
Store
implementation that stores entries in memory. - MemoryStore(long) - Constructor for class com.github.mizosoft.methanol.internal.cache.MemoryStore
- MemoryStoreConfig - Class in com.github.mizosoft.methanol.testing.store
- MemoryStoreConfig(long) - Constructor for class com.github.mizosoft.methanol.testing.store.MemoryStoreConfig
- MemoryStoreContext - Class in com.github.mizosoft.methanol.testing.store
- metadata() - Method in interface com.github.mizosoft.methanol.internal.cache.Store.Viewer
-
Returns the entry's metadata as a readonly buffer.
- methanol - module methanol
-
Core Methanol module.
- Methanol - Class in com.github.mizosoft.methanol
-
An
HttpClient
with interceptors, request decoration, HTTP caching and reactive extensions. - methanol.adapter.gson - module methanol.adapter.gson
-
Provides
BodyAdapter.Encoder
andBodyAdapter.Decoder
implementations for JSON using the Gson library. - methanol.adapter.jackson - module methanol.adapter.jackson
-
Provides
BodyAdapter.Encoder
andBodyAdapter.Decoder
implementations for the Jackson library. - methanol.adapter.jackson.flux - module methanol.adapter.jackson.flux
-
Provides publisher-based
BodyAdapter.Encoder
andBodyAdapter.Decoder
implementations for JSON using the Jackson library and Project Rector. - methanol.adapter.jaxb - module methanol.adapter.jaxb
-
Provides
BodyAdapter.Encoder
andBodyAdapter.Decoder
implementations for XML using JAXB. - methanol.adapter.jaxb.jakarta - module methanol.adapter.jaxb.jakarta
-
Provides
BodyAdapter.Encoder
andBodyAdapter.Decoder
implementations for XML using JAXB. - methanol.adapter.moshi - module methanol.adapter.moshi
-
Contains
BodyAdapter
implementations for JSON using Moshi. - methanol.adapter.protobuf - module methanol.adapter.protobuf
- Methanol.BaseBuilder<B> - Class in com.github.mizosoft.methanol
-
A base
Methanol
builder allowing to set the non-standard properties. - methanol.brotli - module methanol.brotli
-
Provides brotli decompression for Methanol.
- Methanol.Builder - Class in com.github.mizosoft.methanol
-
A builder of
Methanol
instances. - Methanol.Interceptor - Interface in com.github.mizosoft.methanol
-
An object that intercepts requests being sent over a
Methanol
client. - Methanol.Interceptor.Chain<T> - Interface in com.github.mizosoft.methanol
-
An object that gives interceptors the ability to relay requests to sibling interceptors, till eventually being sent by the client's backend.
- methanol.kotlin - module methanol.kotlin
-
Kotlin DSL for Methanol.
- methanol.redis - module methanol.redis
-
Contains a Redis-backed
StorageExtension
implementation. - methanol.testing - module methanol.testing
-
Miscellaneous test utilities used internally.
- Methanol.WithClientBuilder - Class in com.github.mizosoft.methanol
-
A builder for
Methanol
instances with a pre-specified backendHttpClient
. - method() - Method in class com.github.mizosoft.methanol.MutableRequest
- method(String, Object, MediaType) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Sets the request method and sets the payload to the given value.
- method(String, HttpRequest.BodyPublisher) - Method in class com.github.mizosoft.methanol.MutableRequest
- method(String, HttpRequest.BodyPublisher) - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
- method(String, T, TypeRef<T>, MediaType) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Sets the request method and sets the payload to the given value with an explicitly specified type.
- mimeBody() - Method in class com.github.mizosoft.methanol.MutableRequest
- MimeBodyPublisher - Interface in com.github.mizosoft.methanol
-
A
BodyPublisher
with a media type. - MimeBodyPublisherAdapter - Class in com.github.mizosoft.methanol.internal.extensions
- MimeBodyPublisherAdapter(HttpRequest.BodyPublisher, MediaType) - Constructor for class com.github.mizosoft.methanol.internal.extensions.MimeBodyPublisherAdapter
- minFresh() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns the value of the
min-fresh
directive if present. - minFresh(Duration) - Method in class com.github.mizosoft.methanol.CacheControl.Builder
-
Sets the
min-fresh
directive to the given duration. - MISS - Enum constant in enum class com.github.mizosoft.methanol.CacheAwareResponse.CacheStatus
-
Either the cache lacked a matching response or the matching response was stale but failed validation with the server and thus had to be re-downloaded.
- missCount() - Method in interface com.github.mizosoft.methanol.HttpCache.Stats
-
Returns the number of requests resulting in a cache miss, including conditional misses (unsatisfied revalidation requests).
- missRate() - Method in interface com.github.mizosoft.methanol.HttpCache.Stats
-
Returns a value between
0.0
and1.0
representing the ratio between the miss and request counts. - MockClock - Class in com.github.mizosoft.methanol.testing
-
A
Clock
that can be advanced manually or automatically with a specified duration. - MockClock() - Constructor for class com.github.mizosoft.methanol.testing.MockClock
- MockClock(Instant) - Constructor for class com.github.mizosoft.methanol.testing.MockClock
- MockClock(ZoneId, Instant) - Constructor for class com.github.mizosoft.methanol.testing.MockClock
- MockDelayer - Class in com.github.mizosoft.methanol.testing
-
A Delayer that delays tasks based on a
MockClock
's time. - MockDelayer(MockClock) - Constructor for class com.github.mizosoft.methanol.testing.MockDelayer
- MockDelayer(MockClock, boolean) - Constructor for class com.github.mizosoft.methanol.testing.MockDelayer
- MockDelayer.DelayedFuture - Class in com.github.mizosoft.methanol.testing
- mockExecutor() - Method in class com.github.mizosoft.methanol.testing.store.DiskStoreContext
- MockExecutor - Class in com.github.mizosoft.methanol.testing
-
An
Executor
that records submitted tasks and allows running them later. - MockExecutor() - Constructor for class com.github.mizosoft.methanol.testing.MockExecutor
- MockGzipStream - Class in com.github.mizosoft.methanol.testing
-
A mock gzip stream with configurable gzip stream fields
&
corruption modes. - MockGzipStream.Builder - Class in com.github.mizosoft.methanol.testing
- MockGzipStream.CorruptionMode - Enum Class in com.github.mizosoft.methanol.testing
-
Modes to corrupt the gzip stream.
- MockHasher - Class in com.github.mizosoft.methanol.testing.store
-
DiskStore.Hasher
allowing to explicitly set fake hash codes for some keys. - mockTime() - Method in class com.github.mizosoft.methanol.testing.store.DiskStoreConfig
- MockWebServerExtension - Class in com.github.mizosoft.methanol.testing
-
An extension that provides plain or secure
MockWebServers
andMethanol.Builder
either explicitly or by resolving parameters. - MockWebServerExtension() - Constructor for class com.github.mizosoft.methanol.testing.MockWebServerExtension
- MockWebServerExtension.UseHttps - Annotation Interface in com.github.mizosoft.methanol.testing
- MoreBodyHandlers - Class in com.github.mizosoft.methanol
-
Static factories for additional
HttpResponse.BodyHandler
implementations. - MoreBodyPublishers - Class in com.github.mizosoft.methanol
-
Static factories for additional
HttpRequest.BodyPublisher
implementations. - MoreBodySubscribers - Class in com.github.mizosoft.methanol
-
Static factories for additional
HttpResponse.BodySubscriber
implementations. - MultipartBodyPublisher - Class in com.github.mizosoft.methanol
-
A
BodyPublisher
for multipart bodies. - MultipartBodyPublisher.Builder - Class in com.github.mizosoft.methanol
-
A builder of
MultipartBodyPublisher
instances. - MultipartBodyPublisher.Part - Class in com.github.mizosoft.methanol
-
A part in a multipart request body.
- mustRevalidate() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns
true
if themust-revalidate
directive is set. - MutableRequest - Class in com.github.mizosoft.methanol
-
A mutable
HttpRequest
that supportstags
, relative URIs&
setting arbitrary objects as request bodies. - mutate() - Method in interface com.github.mizosoft.methanol.BodyAdapter.Hints
-
Returns a new
Builder
containing this object's hints.
N
- networkResponse() - Method in interface com.github.mizosoft.methanol.CacheAwareResponse
-
Returns an
Optional
for the response received as a result of using the network. - networkResponse() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- networkResponse(TrackedResponse<?>) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- NetworkResponse - Class in com.github.mizosoft.methanol.internal.cache
-
A
RawResponse
that came from the network and may be written to cache. - networkUseCount() - Method in interface com.github.mizosoft.methanol.HttpCache.Stats
-
Returns the number of times the cache had to use the network.
- newBuilder() - Static method in class com.github.mizosoft.methanol.AdapterCodec
-
Returns a new
AdapterCodec.Builder
. - newBuilder() - Static method in interface com.github.mizosoft.methanol.BodyAdapter.Hints
-
Returns a new
Builder
. - newBuilder() - Static method in class com.github.mizosoft.methanol.CacheControl
-
Returns a new
Builder
. - newBuilder() - Static method in class com.github.mizosoft.methanol.FormBodyPublisher
-
Returns a new
FormBodyPublisher.Builder
. - newBuilder() - Static method in class com.github.mizosoft.methanol.HttpCache
-
Returns a new
HttpCache.Builder
. - newBuilder() - Static method in class com.github.mizosoft.methanol.internal.cache.DiskStore
- newBuilder() - Static method in class com.github.mizosoft.methanol.Methanol
-
Returns a new
Methanol.Builder
. - newBuilder() - Static method in class com.github.mizosoft.methanol.MultipartBodyPublisher
-
Returns a new
MultipartBodyPublisher.Builder
. - newBuilder() - Static method in class com.github.mizosoft.methanol.ProgressTracker
-
Returns a new
ProgressTracker.Builder
. - newBuilder() - Static method in interface com.github.mizosoft.methanol.store.redis.RedisStorageExtension
- newBuilder() - Static method in class com.github.mizosoft.methanol.testing.MockGzipStream
- newBuilder(HttpClient) - Static method in class com.github.mizosoft.methanol.Methanol
-
Returns a new
Methanol.WithClientBuilder
with a prebuilt backend. - newBuilder(HttpResponse<T>) - Static method in class com.github.mizosoft.methanol.ResponseBuilder
- newMemoryFileSystem() - Method in interface com.github.mizosoft.methanol.testing.MemoryFileSystemProvider
- newRandom() - Static method in class com.github.mizosoft.methanol.testing.TestUtils
- newReader() - Method in interface com.github.mizosoft.methanol.internal.cache.Store.Viewer
-
Returns a new
Store.EntryReader
that reads the entry's data stream from the start. - newWatchService() - Method in class com.github.mizosoft.methanol.testing.file.LeakDetectingFileSystem
- newWatchService() - Method in class com.github.mizosoft.methanol.testing.file.WindowsEmulatingFileSystem
- newWebSocketBuilder() - Method in class com.github.mizosoft.methanol.Methanol
- next() - Method in class com.github.mizosoft.methanol.testing.ByteBufferIterator
- next() - Method in class com.github.mizosoft.methanol.testing.ByteBufferListIterator
- nextCount() - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- nextMatching(CharMatcher) - Method in class com.github.mizosoft.methanol.internal.text.HeaderValueTokenizer
- nextToken() - Method in class com.github.mizosoft.methanol.internal.text.HeaderValueTokenizer
- nextTokenOrQuotedString() - Method in class com.github.mizosoft.methanol.internal.text.HeaderValueTokenizer
- noCache() - Method in class com.github.mizosoft.methanol.CacheControl.Builder
-
Sets the
no-cache
directive. - noCache() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns
true
if theno-cache
directive is set. - noCacheFields() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns the header fields nominated by
no-cache
if specified. - NONE - Enum constant in enum class com.github.mizosoft.methanol.testing.store.StoreConfig.FileSystemType
- NOOP_SUBSCRIPTION - Static variable in class com.github.mizosoft.methanol.internal.flow.FlowSupport
-
A subscription that does nothing.
- noStore() - Method in class com.github.mizosoft.methanol.CacheControl.Builder
-
Sets the
no-store
directive. - noStore() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns
true
if theno-store
directive is set. - noStoreFields() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns the header fields nominated by
no-store
if specified. - noTransform() - Method in class com.github.mizosoft.methanol.CacheControl.Builder
-
Sets the
no-transform
directive. - noTransform() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns
true
if theno-transform
directive is set.
O
- ObjectReaderFactory - Interface in com.github.mizosoft.methanol.adapter.jackson
-
A strategy for creating an
ObjectReader
for a given type. - ObjectWriterFactory - Interface in com.github.mizosoft.methanol.adapter.jackson
-
A strategy for creating an
ObjectWriter
for a given type. - of(MediaType) - Static method in interface com.github.mizosoft.methanol.BodyAdapter.Hints
-
Returns a
Hints
object containing the given media type. - of(StoreConfig) - Static method in class com.github.mizosoft.methanol.testing.store.StoreContext
- of(Class<U>) - Static method in class com.github.mizosoft.methanol.TypeRef
-
Returns a new
TypeRef
who'sTypeRef.type()
is the given class. - of(Type) - Static method in class com.github.mizosoft.methanol.TypeRef
-
Returns a new
TypeRef
who'sTypeRef.type()
is the given type. - of(String, String) - Static method in class com.github.mizosoft.methanol.MediaType
-
Returns a new
MediaType
with the given type and subtype. - of(String, String, Map<String, String>) - Static method in class com.github.mizosoft.methanol.MediaType
-
Returns a new
MediaType
with the given type, subtype and parameters. - of(ScheduledExecutorService) - Static method in interface com.github.mizosoft.methanol.internal.concurrent.Delayer
- of(Supplier<T>) - Static method in class com.github.mizosoft.methanol.internal.concurrent.Lazy
- ofByteChannel() - Static method in class com.github.mizosoft.methanol.MoreBodyHandlers
-
Returns a
BodyHandler
that returns a subscriber obtained fromMoreBodySubscribers.ofByteChannel()
. - ofByteChannel() - Static method in class com.github.mizosoft.methanol.MoreBodySubscribers
-
Returns a completed
BodySubscriber
ofReadableByteChannel
that reads the response body. - ofDeferredObject(TypeRef<T>) - Static method in class com.github.mizosoft.methanol.MoreBodyHandlers
-
Returns a
BodyHandler
that returns a subscriber obtained fromMoreBodySubscribers.ofDeferredObject(TypeRef, MediaType)
. - ofDeferredObject(TypeRef<T>, MediaType) - Static method in class com.github.mizosoft.methanol.MoreBodySubscribers
-
Returns a
BodySubscriber
that decodes the response body into an object of the given type using an installeddecoder
. - ofDeferredObject(Class<T>) - Static method in class com.github.mizosoft.methanol.MoreBodyHandlers
-
Returns a
BodyHandler
that returns a subscriber obtained fromMoreBodySubscribers.ofDeferredObject(TypeRef, MediaType)
. - ofMediaType(HttpRequest.BodyPublisher, MediaType) - Static method in class com.github.mizosoft.methanol.MoreBodyPublishers
-
Adapts the given
BodyPublisher
into aMimeBodyPublisher
with the given media type. - ofObject(TypeRef<T>) - Static method in class com.github.mizosoft.methanol.MoreBodyHandlers
-
Returns a
BodyHandler
that returns a subscriber obtained fromMoreBodySubscribers.ofObject(TypeRef, MediaType)
. - ofObject(TypeRef<T>, MediaType) - Static method in class com.github.mizosoft.methanol.MoreBodySubscribers
-
Returns a
BodySubscriber
that decodes the response body into an object of the given type using an installeddecoder
. - ofObject(Class<T>) - Static method in class com.github.mizosoft.methanol.MoreBodyHandlers
-
Returns a
BodyHandler
that returns a subscriber obtained fromMoreBodySubscribers.ofObject(TypeRef, MediaType)
. - ofObject(Object, MediaType) - Static method in class com.github.mizosoft.methanol.MoreBodyPublishers
-
Returns a
BodyPublisher
that encodes the given object into a request body using an installedencoder
. - ofOutputStream(ThrowingConsumer<? super OutputStream>, Executor) - Static method in class com.github.mizosoft.methanol.MoreBodyPublishers
-
Returns a
BodyPublisher
that reads what's written to theOutputStream
received by the given task. - ofReader() - Static method in class com.github.mizosoft.methanol.MoreBodyHandlers
-
Returns a
BodyHandler
that returns a subscriber obtained formMoreBodySubscribers.ofReader(Charset)
using the charset specified by theContent-Type
header, orUTF-8
if not present. - ofReader(Charset) - Static method in class com.github.mizosoft.methanol.MoreBodyHandlers
-
Returns a
BodyHandler
that returns a subscriber obtained fromMoreBodySubscribers.ofReader(Charset)
using the given charset. - ofReader(Charset) - Static method in class com.github.mizosoft.methanol.MoreBodySubscribers
-
Returns a completed
BodySubscriber
ofReader
that reads the response body as a stream of characters decoded using the given charset. - ofRuntimeType(T) - Static method in class com.github.mizosoft.methanol.TypeRef
-
Returns a new
TypeRef
who'sTypeRef.type()
is the runtime type of the given instance. - ofWritableByteChannel(ThrowingConsumer<? super WritableByteChannel>, Executor) - Static method in class com.github.mizosoft.methanol.MoreBodyPublishers
-
Returns a
BodyPublisher
that reads what's written to theWritableByteChannel
received by the given task. - okResponseOf(HttpRequest, ByteBuffer, HttpResponse.BodyHandler<T>) - Static method in class com.github.mizosoft.methanol.testing.TestUtils
- okResponseOf(HttpRequest, T) - Static method in class com.github.mizosoft.methanol.testing.TestUtils
- onComplete() - Method in class com.github.mizosoft.methanol.decoder.AsyncBodyDecoder
- onComplete() - Method in class com.github.mizosoft.methanol.internal.extensions.ByteChannelBodySubscriber
- onComplete() - Method in class com.github.mizosoft.methanol.internal.extensions.PublisherBodySubscriber
- onComplete() - Method in class com.github.mizosoft.methanol.internal.flow.ForwardingSubscriber
- onComplete() - Method in class com.github.mizosoft.methanol.internal.flow.SerializedForwardingSubscriber
- onComplete() - Method in class com.github.mizosoft.methanol.internal.flow.TimeoutSubscriber
- onComplete() - Method in interface com.github.mizosoft.methanol.ProgressTracker.Listener
- onComplete() - Method in interface com.github.mizosoft.methanol.ProgressTracker.MultipartListener
- onComplete() - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- onDroppedException(Throwable) - Static method in class com.github.mizosoft.methanol.internal.flow.FlowSupport
- onError(Throwable) - Method in class com.github.mizosoft.methanol.decoder.AsyncBodyDecoder
- onError(Throwable) - Method in class com.github.mizosoft.methanol.internal.extensions.ByteChannelBodySubscriber
- onError(Throwable) - Method in class com.github.mizosoft.methanol.internal.extensions.PublisherBodySubscriber
- onError(Throwable) - Method in class com.github.mizosoft.methanol.internal.flow.ForwardingSubscriber
- onError(Throwable) - Method in class com.github.mizosoft.methanol.internal.flow.SerializedForwardingSubscriber
- onError(Throwable) - Method in class com.github.mizosoft.methanol.internal.flow.TimeoutSubscriber
- onError(Throwable) - Method in interface com.github.mizosoft.methanol.ProgressTracker.Listener
- onError(Throwable) - Method in interface com.github.mizosoft.methanol.ProgressTracker.MultipartListener
- onError(Throwable) - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- onlyIfCached() - Method in class com.github.mizosoft.methanol.CacheControl.Builder
-
Sets the
only-if-cached
directive. - onlyIfCached() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns
true
if theonly-if-cached
directive is set. - onNetworkUse(HttpRequest, TrackedResponse<?>) - Method in interface com.github.mizosoft.methanol.HttpCache.Listener
-
Called when the cache is about to use the network due to a cache miss.
- onNext(List<ByteBuffer>) - Method in class com.github.mizosoft.methanol.decoder.AsyncBodyDecoder
- onNext(List<ByteBuffer>) - Method in class com.github.mizosoft.methanol.internal.extensions.ByteChannelBodySubscriber
- onNext(List<ByteBuffer>) - Method in class com.github.mizosoft.methanol.internal.extensions.PublisherBodySubscriber
- onNext(T) - Method in class com.github.mizosoft.methanol.internal.flow.ForwardingSubscriber
- onNext(T) - Method in class com.github.mizosoft.methanol.internal.flow.SerializedForwardingSubscriber
- onNext(T) - Method in class com.github.mizosoft.methanol.internal.flow.TimeoutSubscriber
- onNext(T) - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- onReadFailure(Throwable) - Method in interface com.github.mizosoft.methanol.internal.cache.CacheReadingPublisher.Listener
- onReadFailure(HttpRequest, Throwable) - Method in interface com.github.mizosoft.methanol.HttpCache.Listener
-
Called when a failure is encountered while reading the response body from cache.
- onReadSuccess() - Method in interface com.github.mizosoft.methanol.internal.cache.CacheReadingPublisher.Listener
- onReadSuccess(HttpRequest) - Method in interface com.github.mizosoft.methanol.HttpCache.Listener
-
Called when the response body has been successfully read from cache.
- onRequest(HttpRequest) - Method in interface com.github.mizosoft.methanol.HttpCache.Listener
-
Called when the cache receives a request.
- onResponse(HttpRequest, CacheAwareResponse<?>) - Method in interface com.github.mizosoft.methanol.HttpCache.Listener
-
Called when the cache is ready to serve the response.
- onSubscribe(Flow.Subscription) - Method in class com.github.mizosoft.methanol.decoder.AsyncBodyDecoder
- onSubscribe(Flow.Subscription) - Method in class com.github.mizosoft.methanol.internal.extensions.ByteChannelBodySubscriber
- onSubscribe(Flow.Subscription) - Method in class com.github.mizosoft.methanol.internal.extensions.PublisherBodySubscriber
- onSubscribe(Flow.Subscription) - Method in class com.github.mizosoft.methanol.internal.flow.ForwardingSubscriber
- onSubscribe(Flow.Subscription) - Method in class com.github.mizosoft.methanol.internal.flow.SerializedForwardingSubscriber
- onSubscribe(Flow.Subscription) - Method in class com.github.mizosoft.methanol.internal.flow.TimeoutSubscriber
- onSubscribe(Flow.Subscription) - Method in interface com.github.mizosoft.methanol.ProgressTracker.Listener
- onSubscribe(Flow.Subscription) - Method in interface com.github.mizosoft.methanol.ProgressTracker.MultipartListener
- onSubscribe(Flow.Subscription) - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- onTick(BiConsumer<Instant, Duration>) - Method in class com.github.mizosoft.methanol.testing.MockClock
- onWriteFailure(Throwable) - Method in interface com.github.mizosoft.methanol.internal.cache.CacheWritingPublisher.Listener
- onWriteFailure(HttpRequest, Throwable) - Method in interface com.github.mizosoft.methanol.HttpCache.Listener
-
Called when a failure is encountered while writing the response to cache.
- onWriteSuccess() - Method in interface com.github.mizosoft.methanol.internal.cache.CacheWritingPublisher.Listener
- onWriteSuccess(HttpRequest) - Method in interface com.github.mizosoft.methanol.HttpCache.Listener
-
Called when the response has been successfully written to cache.
- or(CharMatcher) - Method in interface com.github.mizosoft.methanol.internal.text.CharMatcher
- outputStream() - Method in class com.github.mizosoft.methanol.WritableBodyPublisher
-
Returns a
OutputStream
for writing this body's content. - OWS_MATCHER - Static variable in class com.github.mizosoft.methanol.internal.text.HttpCharMatchers
P
- parameters() - Method in class com.github.mizosoft.methanol.MediaType
-
Returns an immutable map representing the parameters.
- parse(String) - Static method in class com.github.mizosoft.methanol.CacheControl
-
Parses the cache directives specified by the given value.
- parse(String) - Static method in class com.github.mizosoft.methanol.MediaType
-
Parses the given string into a
MediaType
instance. - parse(HttpHeaders) - Static method in class com.github.mizosoft.methanol.CacheControl
-
Parses the cache directives specified by the given headers.
- parse(List<String>) - Static method in class com.github.mizosoft.methanol.CacheControl
-
Parses the cache directives specified by each of the given values.
- parseDeltaSeconds(String) - Static method in class com.github.mizosoft.methanol.internal.cache.HttpDates
- part() - Method in interface com.github.mizosoft.methanol.ProgressTracker.MultipartProgress
-
Returns the currently progressing part.
- part(MultipartBodyPublisher.Part) - Method in class com.github.mizosoft.methanol.MultipartBodyPublisher.Builder
-
Adds the given part.
- partChanged() - Method in interface com.github.mizosoft.methanol.ProgressTracker.MultipartProgress
-
Returns
true
if the currently progressing part has changed from the last event. - partProgress() - Method in interface com.github.mizosoft.methanol.ProgressTracker.MultipartProgress
-
Returns current part's progress.
- parts() - Method in class com.github.mizosoft.methanol.MultipartBodyPublisher
-
Returns an immutable list containing this body's parts.
- PATCH(Object, MediaType) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Sets the request method to PATCH and sets the payload to the given value.
- PATCH(String, Object, MediaType) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a PATCH method. - PATCH(String, HttpRequest.BodyPublisher) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a PATCH method. - PATCH(String, T, TypeRef<T>, MediaType) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a PATCH method. - PATCH(HttpRequest.BodyPublisher) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Sets the request method to PATCH and sets the body publisher to the given value.
- PATCH(URI, Object, MediaType) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a PATCH method. - PATCH(URI, HttpRequest.BodyPublisher) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a PATCH method. - PATCH(URI, T, TypeRef<T>, MediaType) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a PATCH method. - PATCH(T, TypeRef<T>, MediaType) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Sets the request method to PATCH and sets the payload to the given value with an explicitly specified type.
- PayloadHandlerExecutor - Class in com.github.mizosoft.methanol.internal.adapter
-
Holds the executor to be used for handling a
ResponsePayload
. - PayloadHandlerExecutor(Executor) - Constructor for class com.github.mizosoft.methanol.internal.adapter.PayloadHandlerExecutor
- peekAvailable() - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- peekEarliestFuture() - Method in class com.github.mizosoft.methanol.testing.MockDelayer
- peekInstant() - Method in class com.github.mizosoft.methanol.testing.MockClock
-
Returns the clock's time without advancing it.
- peekLatestFuture() - Method in class com.github.mizosoft.methanol.testing.MockDelayer
- poll() - Method in class com.github.mizosoft.methanol.internal.flow.AbstractPollableSubscription
-
Returns the next item, or
null
if no items are available. - poll() - Method in class com.github.mizosoft.methanol.internal.flow.AbstractQueueSubscription
- pollAll() - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- pollNext() - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- pollNext(int) - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- pollNext(int, Duration) - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- position() - Method in class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- position(long) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- POST(Object, MediaType) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Sets the request method to POST and sets the payload to the given value.
- POST(String, Object, MediaType) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a POST method. - POST(String, HttpRequest.BodyPublisher) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a POST method. - POST(String, T, TypeRef<T>, MediaType) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a POST method. - POST(HttpRequest.BodyPublisher) - Method in class com.github.mizosoft.methanol.MutableRequest
- POST(HttpRequest.BodyPublisher) - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
- POST(URI, Object, MediaType) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a POST method. - POST(URI, HttpRequest.BodyPublisher) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a POST method. - POST(URI, T, TypeRef<T>, MediaType) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a POST method. - POST(T, TypeRef<T>, MediaType) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Sets the request method to POST and sets the payload to the given value with an explicitly specified type.
- postDecorationInterceptor(Methanol.Interceptor) - Method in class com.github.mizosoft.methanol.Methanol.BaseBuilder
-
Deprecated.
- postDecorationInterceptors() - Method in class com.github.mizosoft.methanol.Methanol
-
Deprecated.
- prefetch() - Static method in class com.github.mizosoft.methanol.internal.flow.FlowSupport
-
Returns the prefetch property or a default of 8.
- Prefetcher - Class in com.github.mizosoft.methanol.internal.flow
-
An object that manages requests to an upstream subscription according to a prefetching policy.
- Prefetcher() - Constructor for class com.github.mizosoft.methanol.internal.flow.Prefetcher
- Prefetcher(int, int) - Constructor for class com.github.mizosoft.methanol.internal.flow.Prefetcher
- prefetchThreshold() - Static method in class com.github.mizosoft.methanol.internal.flow.FlowSupport
-
Returns the prefetch threshold according to the prefetch factor property or a default of 8
/ 2
. - previousResponse() - Method in class com.github.mizosoft.methanol.testing.HttpResponseStub
- previousResponse() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- previousResponse(HttpResponse<T>) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- priority(int) - Method in class com.github.mizosoft.methanol.Methanol.Builder
- privateFields() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns the header fields nominated by
private
if specified. - probeContentType(Path) - Method in class com.github.mizosoft.methanol.testing.RegistryFileTypeDetector
- ProgressTracker - Class in com.github.mizosoft.methanol
-
A progress tracker for upload and download operations.
- ProgressTracker.Builder - Class in com.github.mizosoft.methanol
-
A builder of
ProgressTrackers
. - ProgressTracker.Listener - Interface in com.github.mizosoft.methanol
-
A listener of
progress events
. - ProgressTracker.MultipartListener - Interface in com.github.mizosoft.methanol
- ProgressTracker.MultipartProgress - Interface in com.github.mizosoft.methanol
-
A progress event for a multipart body with per-part progress info.
- ProgressTracker.Progress - Interface in com.github.mizosoft.methanol
-
A progress event.
- propagateIfUnchecked(Throwable) - Static method in class com.github.mizosoft.methanol.internal.function.Unchecked
- ProtobufAdapterFactory - Class in com.github.mizosoft.methanol.adapter.protobuf
-
Providers
BodyAdapter
for Google's Protocol Buffers format. - protocolViolations() - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- provideArguments(ExtensionContext) - Method in class com.github.mizosoft.methanol.testing.ExecutorExtension
- provideArguments(ExtensionContext) - Method in class com.github.mizosoft.methanol.testing.store.StoreExtension
- provider() - Method in class com.github.mizosoft.methanol.testing.file.LeakDetectingFileSystem
- provider() - Method in class com.github.mizosoft.methanol.testing.file.WindowsEmulatingFileSystem
- proxy() - Method in class com.github.mizosoft.methanol.Methanol
- proxy() - Method in class com.github.mizosoft.methanol.testing.HttpClientStub
- proxy() - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient
- proxy(ProxySelector) - Method in class com.github.mizosoft.methanol.Methanol.Builder
- proxyRevalidate() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns
true
if theproxy-revalidate
directive is set. - PublisherBodySubscriber - Class in com.github.mizosoft.methanol.internal.extensions
-
A
HttpResponse.BodySubscriber
that exposes the response body as a publisher. - PublisherBodySubscriber() - Constructor for class com.github.mizosoft.methanol.internal.extensions.PublisherBodySubscriber
- publisherOf(T, BodyAdapter.Hints) - Method in class com.github.mizosoft.methanol.AdapterCodec
-
Returns a
HttpRequest.BodyPublisher
that encodes the given object into a request body. - publisherOf(T, TypeRef<T>, BodyAdapter.Hints) - Method in class com.github.mizosoft.methanol.AdapterCodec
-
Returns a
HttpRequest.BodyPublisher
that encodes the given object into a request body with respect to the givenTypeRef
. - publishing(String) - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.BodySubscriberVerifier
- publishing(ByteBuffer) - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.BodySubscriberVerifier
- pullBytes(ByteBuffer) - Method in interface com.github.mizosoft.methanol.decoder.AsyncDecoder.ByteSource
-
Pulls
min(this.remaining(), dst.remaining())
bytes from this source to the given destination buffer. - pushBytes(ByteBuffer) - Method in interface com.github.mizosoft.methanol.decoder.AsyncDecoder.ByteSink
-
Pushes
src.remaining()
bytes from the given source buffer to this sink. - pushPromiseHandler() - Method in interface com.github.mizosoft.methanol.Methanol.Interceptor.Chain
-
Returns the
PushPromiseHandler
this chain uses for handling push promises. - pushPromiseHandler() - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient.Call
- put(Class<T>, T) - Method in class com.github.mizosoft.methanol.BodyAdapter.Hints.Builder
-
Maps the given type to the given hint.
- put(HttpRequest, NetworkResponse, CacheResponse) - Method in interface com.github.mizosoft.methanol.internal.cache.LocalCache
- PUT(Object, MediaType) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Sets the request method to PUT and sets the payload to the given value.
- PUT(String, Object, MediaType) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a PUT method. - PUT(String, HttpRequest.BodyPublisher) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a PUT method. - PUT(String, T, TypeRef<T>, MediaType) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a PUT method. - PUT(HttpRequest.BodyPublisher) - Method in class com.github.mizosoft.methanol.MutableRequest
- PUT(HttpRequest.BodyPublisher) - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
- PUT(URI, Object, MediaType) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a PUT method. - PUT(URI, HttpRequest.BodyPublisher) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a PUT method. - PUT(URI, T, TypeRef<T>, MediaType) - Static method in class com.github.mizosoft.methanol.MutableRequest
-
Returns a new
MutableRequest
with the given URI and a PUT method. - PUT(T, TypeRef<T>, MediaType) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Sets the request method to PUT and sets the payload to the given value with an explicitly specified type.
Q
- queries() - Method in class com.github.mizosoft.methanol.FormBodyPublisher
-
Returns this body's queries.
- query(String, String) - Method in class com.github.mizosoft.methanol.FormBodyPublisher.Builder
-
Adds the query specified by the given name and value.
- QUOTED_PAIR_MATCHER - Static variable in class com.github.mizosoft.methanol.internal.text.HttpCharMatchers
- QUOTED_TEXT_MATCHER - Static variable in class com.github.mizosoft.methanol.internal.text.HttpCharMatchers
R
- RawResponse - Class in com.github.mizosoft.methanol.internal.cache
-
A response with a "raw" body that is yet to be handled.
- rawType() - Method in class com.github.mizosoft.methanol.TypeRef
-
Returns the
Class<? super T>
that represents the resolved raw type ofTypeRef
. - read(Store.EntryReader) - Static method in class com.github.mizosoft.methanol.testing.store.StoreTesting
- read(Store.Viewer) - Static method in class com.github.mizosoft.methanol.testing.store.StoreTesting
- read(ByteBuffer) - Method in interface com.github.mizosoft.methanol.internal.cache.Store.EntryReader
-
Synchronous variant of
Store.EntryReader.read(ByteBuffer, Executor)
. - read(ByteBuffer) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- read(ByteBuffer[], int, int) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- read(ByteBuffer, long) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingAsynchronousFileChannel
- read(ByteBuffer, long) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- read(ByteBuffer, long, A, CompletionHandler<Integer, ? super A>) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingAsynchronousFileChannel
- read(ByteBuffer, Executor) - Method in interface com.github.mizosoft.methanol.internal.cache.Store.EntryReader
-
Reads as many bytes as possible from the data stream into the given buffer, and returns the number of read bytes, or
-1
if reached EOF. - read(List<ByteBuffer>) - Method in interface com.github.mizosoft.methanol.internal.cache.Store.EntryReader
-
Synchronous variant of
Store.EntryReader.read(List, Executor)
. - read(List<ByteBuffer>, Executor) - Method in interface com.github.mizosoft.methanol.internal.cache.Store.EntryReader
-
Reads as many bytes as possible from the data stream into the given buffers, in sequential order, and returns the number of read bytes, or
-1
if reached EOF. - readFailureCount() - Method in interface com.github.mizosoft.methanol.HttpCache.Stats
-
Returns the number of times a response wasn't read from cache due to a read failure.
- readSuccessCount() - Method in interface com.github.mizosoft.methanol.HttpCache.Stats
-
Returns the number of times a response was successfully read from cache.
- readTimeout() - Method in class com.github.mizosoft.methanol.Methanol
-
Returns the
read timeout
used for each request. - readTimeout(Duration) - Method in class com.github.mizosoft.methanol.Methanol.BaseBuilder
-
Sets a default
read timeout
. - readTimeout(Duration, ScheduledExecutorService) - Method in class com.github.mizosoft.methanol.Methanol.BaseBuilder
-
Sets a default
readtimeout
using the givenScheduledExecutorService
for scheduling timeout events. - recordHit(URI) - Method in interface com.github.mizosoft.methanol.HttpCache.StatsRecorder
-
Called when a request results in a cache hit, either directly or after successful revalidation with the server.
- RecordingHttpClient - Class in com.github.mizosoft.methanol.testing
- RecordingHttpClient() - Constructor for class com.github.mizosoft.methanol.testing.RecordingHttpClient
- RecordingHttpClient.Call<T> - Class in com.github.mizosoft.methanol.testing
- recordMiss(URI) - Method in interface com.github.mizosoft.methanol.HttpCache.StatsRecorder
-
Called when a request results in a cache miss, either due to a missing cache entry or after failed revalidation with the server.
- recordNetworkUse(URI) - Method in interface com.github.mizosoft.methanol.HttpCache.StatsRecorder
-
Called when the cache is about to use the network.
- recordReadFailure(URI) - Method in interface com.github.mizosoft.methanol.HttpCache.StatsRecorder
-
Called when a failure is encountered while reading a response from cache.
- recordReadSuccess(URI) - Method in interface com.github.mizosoft.methanol.HttpCache.StatsRecorder
-
Called when a response is successfully read from cache.
- recordRequest(URI) - Method in interface com.github.mizosoft.methanol.HttpCache.StatsRecorder
-
Called when a request is intercepted by the cache.
- recordWriteFailure(URI) - Method in interface com.github.mizosoft.methanol.HttpCache.StatsRecorder
-
Called when a failure is encountered while writing a response to cache.
- recordWriteSuccess(URI) - Method in interface com.github.mizosoft.methanol.HttpCache.StatsRecorder
-
Called when a response is successfully written to cache.
- RedirectingInterceptor - Class in com.github.mizosoft.methanol.internal.cache
-
An
Methanol.Interceptor
that follows redirects. - RedirectingInterceptor(HttpClient.Redirect, Executor) - Constructor for class com.github.mizosoft.methanol.internal.cache.RedirectingInterceptor
- REDIS_CLUSTER - Enum constant in enum class com.github.mizosoft.methanol.testing.store.StoreConfig.StoreType
- REDIS_STANDALONE - Enum constant in enum class com.github.mizosoft.methanol.testing.store.StoreConfig.StoreType
- RedisClusterSession - Class in com.github.mizosoft.methanol.testing.store
- RedisClusterStoreConfig - Class in com.github.mizosoft.methanol.testing.store
- RedisClusterStoreConfig(int, int, int) - Constructor for class com.github.mizosoft.methanol.testing.store.RedisClusterStoreConfig
- RedisClusterStoreContext - Class in com.github.mizosoft.methanol.testing.store
- RedisConnectionProvider<C> - Interface in com.github.mizosoft.methanol.store.redis
-
A strategy for connecting to Redis using Lettuce.
- RedisSession - Interface in com.github.mizosoft.methanol.testing.store
-
A session with a Redis Standalone or Cluster setup.
- RedisStandaloneSession - Class in com.github.mizosoft.methanol.testing.store
- RedisStandaloneStoreConfig - Class in com.github.mizosoft.methanol.testing.store
- RedisStandaloneStoreConfig(int, int, int) - Constructor for class com.github.mizosoft.methanol.testing.store.RedisStandaloneStoreConfig
- RedisStandaloneStoreContext - Class in com.github.mizosoft.methanol.testing.store
- RedisStorageExtension - Interface in com.github.mizosoft.methanol.store.redis
-
A
StorageExtension
that provides storage on either a Redis Standalone instance or a Redis Cluster. - RedisStorageExtension.Builder - Class in com.github.mizosoft.methanol.store.redis
-
A builder of
RedisStorageExtension
. - register(String, MediaType) - Static method in class com.github.mizosoft.methanol.testing.RegistryFileTypeDetector
- RegistryFileTypeDetector - Class in com.github.mizosoft.methanol.testing
-
A
FileTypeDetector
that pulls media types from registered entries. - RegistryFileTypeDetector() - Constructor for class com.github.mizosoft.methanol.testing.RegistryFileTypeDetector
- reject(boolean) - Method in class com.github.mizosoft.methanol.testing.MockExecutor
- reject(Flow.Subscriber<?>, Throwable) - Static method in class com.github.mizosoft.methanol.internal.flow.FlowSupport
- rejectMulticast(Flow.Subscriber<?>) - Static method in class com.github.mizosoft.methanol.internal.flow.FlowSupport
- release(C) - Method in interface com.github.mizosoft.methanol.store.redis.RedisConnectionProvider
-
Specifies that a connection returned by this provider is not needed anymore.
- remaining() - Method in interface com.github.mizosoft.methanol.decoder.AsyncDecoder.ByteSource
-
Returns the total number of bytes remaining in this source.
- remaining(ByteBuffer[]) - Static method in class com.github.mizosoft.methanol.internal.Utils
- remaining(List<ByteBuffer>) - Static method in class com.github.mizosoft.methanol.internal.Utils
- remove(Class<T>) - Method in class com.github.mizosoft.methanol.BodyAdapter.Hints.Builder
-
Removes the hint mapped to by the given type.
- remove(String) - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore
- remove(String) - Method in class com.github.mizosoft.methanol.internal.cache.MemoryStore
- remove(String) - Method in interface com.github.mizosoft.methanol.internal.cache.Store
-
Removes the entry associated with the given key.
- remove(String) - Method in class com.github.mizosoft.methanol.internal.extensions.HeadersBuilder
- remove(HttpRequest) - Method in class com.github.mizosoft.methanol.HttpCache
-
Removes the entry associated with the given request if one is present.
- remove(URI) - Method in class com.github.mizosoft.methanol.HttpCache
-
Removes the entry associated with the given URI if one is present.
- removeAll() - Method in class com.github.mizosoft.methanol.BodyAdapter.Hints.Builder
-
Removes all hints added so far.
- removeAll(List<String>) - Method in interface com.github.mizosoft.methanol.internal.cache.Store
-
Removes all the entries associated with the given keys.
- removeAll(List<URI>) - Method in interface com.github.mizosoft.methanol.internal.cache.LocalCache
- removeEntry() - Method in interface com.github.mizosoft.methanol.internal.cache.Store.Viewer
-
Removes the entry associated with this viewer only if it hasn't changed since this viewer was opened.
- removeHeader(String) - Method in interface com.github.mizosoft.methanol.HeadersAccumulator
-
Removes all the header values associated with the given name.
- removeHeader(String) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Removes any header associated with the given name.
- removeHeader(String) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- removeHeaders() - Method in interface com.github.mizosoft.methanol.HeadersAccumulator
-
Removes all the headers added so far.
- removeHeaders() - Method in class com.github.mizosoft.methanol.MutableRequest
-
Removes all headers added so far.
- removeHeaders() - Method in class com.github.mizosoft.methanol.ResponseBuilder
- removeHeadersIf(BiPredicate<String, String>) - Method in interface com.github.mizosoft.methanol.HeadersAccumulator
-
Removes all the header name-value pairs matched by the given predicate.
- removeHeadersIf(BiPredicate<String, String>) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Removes all headers matched by the given predicate.
- removeHeadersIf(BiPredicate<String, String>) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- removeIf(BiPredicate<String, String>) - Method in class com.github.mizosoft.methanol.internal.extensions.HeadersBuilder
- removeTag(TypeRef<?>) - Method in class com.github.mizosoft.methanol.MutableRequest
- removeTag(TypeRef<?>) - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
-
Removes the tag associated with the given type.
- removeTag(Class<?>) - Method in class com.github.mizosoft.methanol.MutableRequest
- removeTag(Class<?>) - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
-
Removes the tag associated with the given type.
- RepeatArguments - Annotation Interface in com.github.mizosoft.methanol.testing
-
Meant for
ArgumentsProvider
implementations to know how many times the same arguments should be repeated. - RepeatArgumentsSupport - Class in com.github.mizosoft.methanol.testing
- repeatedly(Consumer<BodyPublisherVerifier>) - Method in class com.github.mizosoft.methanol.testing.verifiers.BodyPublisherVerifier
-
Repeats the verification twice to ensure result repeatability.
- request() - Method in interface com.github.mizosoft.methanol.BodyAdapter.Hints
-
Returns the
HttpRequest
hint. - request() - Method in class com.github.mizosoft.methanol.testing.HttpResponseStub
- request() - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient.Call
- request(long) - Method in class com.github.mizosoft.methanol.internal.flow.AbstractSubscription
- request(long) - Method in class com.github.mizosoft.methanol.internal.flow.Upstream
-
Requests
n
items from upstream if set. - request(long) - Method in class com.github.mizosoft.methanol.testing.TestSubscription
- request(HttpRequest) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- requestCount() - Method in interface com.github.mizosoft.methanol.HttpCache.Stats
-
Returns the number of requests intercepted by the cache.
- requestCount() - Method in class com.github.mizosoft.methanol.testing.TestSubscription
- requestItems(long) - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- requestTimeout() - Method in class com.github.mizosoft.methanol.Methanol
-
Returns the default request timeout used when not set in an
HttpRequest
. - requestTimeout(Duration) - Method in class com.github.mizosoft.methanol.Methanol.BaseBuilder
-
Sets a default request timeout to use when not explicitly by an
HttpRequest
. - RequestVerifier - Class in com.github.mizosoft.methanol.testing.verifiers
-
A small DSL for testing
HttpRequests
. - RequestVerifier(HttpRequest) - Constructor for class com.github.mizosoft.methanol.testing.verifiers.RequestVerifier
- requestWasSentAt(Instant) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- requireArgument(boolean, String) - Static method in class com.github.mizosoft.methanol.internal.Validate
- requireArgument(boolean, String, Object...) - Static method in class com.github.mizosoft.methanol.internal.Validate
- requireCharacter(char) - Method in class com.github.mizosoft.methanol.internal.text.HeaderValueTokenizer
- requireCompatibleOrNull(MediaType) - Method in class com.github.mizosoft.methanol.adapter.AbstractBodyAdapter
-
Requires that either this adapter is
compatible
with the given media type, or the given media type isnull
. - requiredPushPromiseHandler() - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient.Call
- requireNonNegativeDuration(Duration) - Static method in class com.github.mizosoft.methanol.internal.Utils
- requirePositiveDuration(Duration) - Static method in class com.github.mizosoft.methanol.internal.Utils
- requireState(boolean, String) - Static method in class com.github.mizosoft.methanol.internal.Validate
- requireState(boolean, String, Object...) - Static method in class com.github.mizosoft.methanol.internal.Validate
- requireSupport(TypeRef<?>) - Method in class com.github.mizosoft.methanol.adapter.AbstractBodyAdapter
-
Requires that this adapter
supports
the given type. - requireSupport(TypeRef<?>, BodyAdapter.Hints) - Method in class com.github.mizosoft.methanol.adapter.AbstractBodyAdapter
-
Requires that this adapter
supports
the given type andis compatible with
the given hints' media type, if any. - requireSupport(Class<?>) - Method in class com.github.mizosoft.methanol.adapter.AbstractBodyAdapter
-
Requires that this adapter
supports
the given type. - requireValidHeader(String, String) - Static method in class com.github.mizosoft.methanol.internal.Utils
- requireValidHeaderName(String) - Static method in class com.github.mizosoft.methanol.internal.Utils
- requireValidHeaderValue(String) - Static method in class com.github.mizosoft.methanol.internal.Utils
- requireValidToken(S) - Static method in class com.github.mizosoft.methanol.internal.Utils
- reset() - Method in class com.github.mizosoft.methanol.testing.store.RedisClusterSession
- reset() - Method in interface com.github.mizosoft.methanol.testing.store.RedisSession
-
Resets this session to its initial state.
- reset() - Method in class com.github.mizosoft.methanol.testing.store.RedisStandaloneSession
- resolveParameter(ParameterContext, ExtensionContext) - Method in class com.github.mizosoft.methanol.testing.ExecutorExtension
- resolveParameter(ParameterContext, ExtensionContext) - Method in class com.github.mizosoft.methanol.testing.MockWebServerExtension
- resolveParameter(ParameterContext, ExtensionContext) - Method in class com.github.mizosoft.methanol.testing.store.StoreExtension
- resolveParameter(ParameterContext, ExtensionContext) - Method in class com.github.mizosoft.methanol.testing.TestSubscriberExtension
- resolveSupertype(Class<?>) - Method in class com.github.mizosoft.methanol.TypeRef
-
Resolves the given supertype into a type with concrete type arguments (if any) that are derived from this type (i.e.
- ResponseBuilder<T> - Class in com.github.mizosoft.methanol
-
A builder of
HttpResponse
instances. - ResponseBuilder() - Constructor for class com.github.mizosoft.methanol.ResponseBuilder
- responseInfo() - Method in interface com.github.mizosoft.methanol.BodyAdapter.Hints
-
Returns the
ResponseInfo
hint. - ResponsePayload - Interface in com.github.mizosoft.methanol
-
A response body that is yet to be handled into the desirable type.
- ResponseVerifier<T> - Class in com.github.mizosoft.methanol.testing.verifiers
-
A small DSL for testing
HttpResponses
. - ResponseVerifier(HttpResponse<T>) - Constructor for class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- responseWasReceivedAt(Instant) - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- run() - Method in interface com.github.mizosoft.methanol.internal.function.ThrowingRunnable
- runAll() - Method in class com.github.mizosoft.methanol.testing.MockExecutor
- runAsync(ThrowingRunnable, Executor) - Static method in class com.github.mizosoft.methanol.internal.function.Unchecked
- runnable(ThrowingRunnable) - Static method in class com.github.mizosoft.methanol.internal.function.Unchecked
- runNext() - Method in class com.github.mizosoft.methanol.testing.MockExecutor
S
- SAME_THREAD - Enum constant in enum class com.github.mizosoft.methanol.testing.ExecutorExtension.ExecutorType
- SAME_THREAD - Enum constant in enum class com.github.mizosoft.methanol.testing.store.StoreConfig.Execution
- SCHEDULER - Enum constant in enum class com.github.mizosoft.methanol.testing.ExecutorExtension.ExecutorType
- send(HttpRequest, TypeRef<T>) - Method in class com.github.mizosoft.methanol.Methanol
-
Sends
the given request and converts the response body into an object of the given type. - send(HttpRequest, Class<T>) - Method in class com.github.mizosoft.methanol.Methanol
-
Sends
the given request and converts the response body into an object of the given type. - send(HttpRequest, HttpResponse.BodyHandler<T>) - Method in class com.github.mizosoft.methanol.Methanol
- send(HttpRequest, HttpResponse.BodyHandler<T>) - Method in class com.github.mizosoft.methanol.testing.HttpClientStub
- send(HttpRequest, HttpResponse.BodyHandler<T>) - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient
- sendAsync(HttpRequest, TypeRef<T>) - Method in class com.github.mizosoft.methanol.Methanol
-
Asynchronously sends
the given request and converts the response body into an object of the given type. - sendAsync(HttpRequest, Class<T>) - Method in class com.github.mizosoft.methanol.Methanol
-
Asynchronously sends
the given request and converts the response body into an object of the given type. - sendAsync(HttpRequest, HttpResponse.BodyHandler<T>) - Method in class com.github.mizosoft.methanol.Methanol
- sendAsync(HttpRequest, HttpResponse.BodyHandler<T>) - Method in class com.github.mizosoft.methanol.testing.HttpClientStub
- sendAsync(HttpRequest, HttpResponse.BodyHandler<T>) - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient
- sendAsync(HttpRequest, HttpResponse.BodyHandler<T>, HttpResponse.PushPromiseHandler<T>) - Method in class com.github.mizosoft.methanol.Methanol
- sendAsync(HttpRequest, HttpResponse.BodyHandler<T>, HttpResponse.PushPromiseHandler<T>) - Method in class com.github.mizosoft.methanol.testing.HttpClientStub
- sendAsync(HttpRequest, HttpResponse.BodyHandler<T>, HttpResponse.PushPromiseHandler<T>) - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient
- sendCount() - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient
- SerialExecutor - Class in com.github.mizosoft.methanol.internal.concurrent
-
An executor that ensures submitted tasks are executed serially.
- SerialExecutor(Executor) - Constructor for class com.github.mizosoft.methanol.internal.concurrent.SerialExecutor
- SerializedForwardingSubscriber<T> - Class in com.github.mizosoft.methanol.internal.flow
-
A forwarding subscriber that ensures the delegate isn't called concurrently.
- SerializedForwardingSubscriber() - Constructor for class com.github.mizosoft.methanol.internal.flow.SerializedForwardingSubscriber
- ServiceProviders<S> - Class in com.github.mizosoft.methanol.internal.spi
-
An object that loads & caches service providers.
- ServiceProviders(Class<S>) - Constructor for class com.github.mizosoft.methanol.internal.spi.ServiceProviders
- set(String, String) - Method in class com.github.mizosoft.methanol.internal.extensions.HeadersBuilder
- set(String, List<String>) - Method in class com.github.mizosoft.methanol.internal.extensions.HeadersBuilder
- setHash(String, long) - Method in class com.github.mizosoft.methanol.testing.store.MockHasher
- setHeader(String, String) - Method in interface com.github.mizosoft.methanol.HeadersAccumulator
-
Sets the header represented by the given name to the given value, overwriting the previous value (if any).
- setHeader(String, String) - Method in class com.github.mizosoft.methanol.MutableRequest
- setHeader(String, String) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- setHeader(String, String) - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
- setHeader(String, List<String>) - Method in interface com.github.mizosoft.methanol.HeadersAccumulator
-
Sets the header represented by the given name to the given values, overwriting the previous value (if any).
- setHeader(String, List<String>) - Method in class com.github.mizosoft.methanol.MutableRequest
- setHeader(String, List<String>) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- setHeaderIfAbsent(String, String) - Method in interface com.github.mizosoft.methanol.HeadersAccumulator
-
Sets the header represented by the given name to the given value, only if there was no header with the given name.
- setHeaderIfAbsent(String, String) - Method in class com.github.mizosoft.methanol.MutableRequest
- setHeaderIfAbsent(String, String) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- setHeaderIfAbsent(String, List<String>) - Method in interface com.github.mizosoft.methanol.HeadersAccumulator
-
Sets the header represented by the given name to the given values, only if there was no header with the given name.
- setHeaderIfAbsent(String, List<String>) - Method in class com.github.mizosoft.methanol.MutableRequest
- setHeaderIfAbsent(String, List<String>) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- setIfAbsent(String, String) - Method in class com.github.mizosoft.methanol.internal.extensions.HeadersBuilder
- setIfAbsent(String, List<String>) - Method in class com.github.mizosoft.methanol.internal.extensions.HeadersBuilder
- setLenient(String, List<String>) - Method in class com.github.mizosoft.methanol.internal.extensions.HeadersBuilder
- setMetadata(Store, String, String) - Static method in class com.github.mizosoft.methanol.testing.store.StoreTesting
- setOrCancel(Flow.Subscription) - Method in class com.github.mizosoft.methanol.internal.flow.Upstream
-
Sets incoming subscription, cancels it if already set.
- setText() - Method in class com.github.mizosoft.methanol.testing.MockGzipStream.Builder
- shutdown() - Method in class com.github.mizosoft.methanol.internal.concurrent.SerialExecutor
- shutdown(Executor...) - Static method in class com.github.mizosoft.methanol.testing.TestUtils
- singleton(Store) - Static method in interface com.github.mizosoft.methanol.internal.cache.InternalStorageExtension
- size() - Method in class com.github.mizosoft.methanol.HttpCache
-
Returns the size this cache occupies in bytes.
- size() - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore
- size() - Method in class com.github.mizosoft.methanol.internal.cache.MemoryStore
- size() - Method in interface com.github.mizosoft.methanol.internal.cache.Store
-
Returns the size in bytes of all entries in this store.
- size() - Method in class com.github.mizosoft.methanol.testing.file.ForwardingAsynchronousFileChannel
- size() - Method in class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- sizeOf(String...) - Static method in class com.github.mizosoft.methanol.testing.store.StoreTesting
- skipped() - Element in annotation interface com.github.mizosoft.methanol.testing.store.StoreSpec
-
Specifies
StoreTypes
to skip in testing. - SLOW_TIMEOUT_SECONDS - Static variable in class com.github.mizosoft.methanol.testing.TestUtils
- sMaxAge() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns the value of the
s-maxage
directive if present. - snapshot() - Method in interface com.github.mizosoft.methanol.HttpCache.StatsRecorder
-
Returns a
Stats
snapshot for the recorded statistics for allURIs
. - snapshot(URI) - Method in interface com.github.mizosoft.methanol.HttpCache.StatsRecorder
-
Returns a
Stats
snapshot for the recorded statistics of the givenURI
. - sslContext() - Method in class com.github.mizosoft.methanol.Methanol
- sslContext() - Method in class com.github.mizosoft.methanol.testing.HttpClientStub
- sslContext() - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient
- sslContext(SSLContext) - Method in class com.github.mizosoft.methanol.Methanol.Builder
- sslParameters() - Method in class com.github.mizosoft.methanol.Methanol
- sslParameters() - Method in class com.github.mizosoft.methanol.testing.HttpClientStub
- sslParameters() - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient
- sslParameters(SSLParameters) - Method in class com.github.mizosoft.methanol.Methanol.Builder
- sslSession() - Method in class com.github.mizosoft.methanol.testing.HttpResponseStub
- sslSession() - Method in class com.github.mizosoft.methanol.testing.verifiers.ResponseVerifier
- sslSession(SSLSession) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- staleEntryInactiveTtlSeconds() - Method in class com.github.mizosoft.methanol.testing.store.RedisClusterStoreConfig
- staleEntryInactiveTtlSeconds() - Method in class com.github.mizosoft.methanol.testing.store.RedisStandaloneStoreConfig
- staleEntryInactiveTtlSeconds() - Element in annotation interface com.github.mizosoft.methanol.testing.store.StoreSpec
-
The number of seconds an inactive stale entry gets to live.
- staleEntryInactiveTtlSeconds(int) - Method in class com.github.mizosoft.methanol.store.redis.RedisStorageExtension.Builder
-
Specifies the number of seconds a stale entry remains valid for already active readers after being deleted or replaced with a new entry by an editor (writer).
- staleIfError() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns the value of the
stale-if-error
directive if present. - staleIfError(Duration) - Method in class com.github.mizosoft.methanol.CacheControl.Builder
-
Sets the
stale-if-error
directive to the given duration. - staleWhileRevalidate() - Method in class com.github.mizosoft.methanol.CacheControl
-
Returns the value of the
stale-while-revalidate
directive if present. - standalone(RedisConnectionProvider<StatefulRedisConnection<String, ByteBuffer>>) - Method in class com.github.mizosoft.methanol.store.redis.RedisStorageExtension.Builder
-
Specifies the connection provider used to connect to the Redis Standalone instance
- standalone(RedisURI) - Method in class com.github.mizosoft.methanol.store.redis.RedisStorageExtension.Builder
-
Specifies the URI of the Redis Standalone instance.
- standalone(RedisURI, RedisClient) - Method in class com.github.mizosoft.methanol.store.redis.RedisStorageExtension.Builder
-
Specifies the URI of the Redis Standalone instance and the client used to connect to it.
- start() - Static method in class com.github.mizosoft.methanol.testing.store.RedisStandaloneSession
- start(int, int) - Static method in class com.github.mizosoft.methanol.testing.store.RedisClusterSession
- start(Map<String, String>) - Static method in class com.github.mizosoft.methanol.testing.store.RedisStandaloneSession
- startsWithIgnoreCase(String, String) - Static method in class com.github.mizosoft.methanol.internal.Utils
- stats() - Method in class com.github.mizosoft.methanol.HttpCache
-
Returns a snapshot of statistics accumulated so far.
- stats(URI) - Method in class com.github.mizosoft.methanol.HttpCache
-
Returns a snapshot of statistics accumulated so far for the given
URI
. - statsRecorder(HttpCache.StatsRecorder) - Method in class com.github.mizosoft.methanol.HttpCache.Builder
-
Sets the cache's
StatsRecorder
. - statusCode() - Method in class com.github.mizosoft.methanol.internal.extensions.ImmutableResponseInfo
- statusCode() - Method in class com.github.mizosoft.methanol.testing.HttpResponseStub
- statusCode() - Method in class com.github.mizosoft.methanol.testing.ImmutableResponseInfo
- statusCode(int) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- StorageExtension - Interface in com.github.mizosoft.methanol
-
An extension that provides a storage backend for an
HttpCache
. - Store - Interface in com.github.mizosoft.methanol.internal.cache
-
A repository of binary data entries each identified by a string key.
- Store.Editor - Interface in com.github.mizosoft.methanol.internal.cache
-
Writes an entry's metadata block and data stream.
- Store.EntryReader - Interface in com.github.mizosoft.methanol.internal.cache
-
A reader for an entry's data stream.
- Store.EntryWriter - Interface in com.github.mizosoft.methanol.internal.cache
-
A writer for an entry's data stream.
- Store.Viewer - Interface in com.github.mizosoft.methanol.internal.cache
-
Reads an entry's metadata block and data stream.
- StoreConfig - Class in com.github.mizosoft.methanol.testing.store
- StoreConfig.Execution - Enum Class in com.github.mizosoft.methanol.testing.store
- StoreConfig.FileSystemType - Enum Class in com.github.mizosoft.methanol.testing.store
- StoreConfig.StoreType - Enum Class in com.github.mizosoft.methanol.testing.store
- StoreContext - Class in com.github.mizosoft.methanol.testing.store
-
Creates and manages
Store
instances corresponding to a given configuration. - StoreCorruptionException - Exception Class in com.github.mizosoft.methanol.internal.cache
- StoreCorruptionException(String) - Constructor for exception class com.github.mizosoft.methanol.internal.cache.StoreCorruptionException
- StoreExtension - Class in com.github.mizosoft.methanol.testing.store
-
Extension
that injectsStore
instances with multiple configurations. - StoreExtension() - Constructor for class com.github.mizosoft.methanol.testing.store.StoreExtension
- StoreExtension.StoreParameterizedTest - Annotation Interface in com.github.mizosoft.methanol.testing.store
- StoreExtension.StoreSource - Annotation Interface in com.github.mizosoft.methanol.testing.store
- StoreSpec - Annotation Interface in com.github.mizosoft.methanol.testing.store
-
Specifies one or more
Store
configurations for a test case. - StoreTesting - Class in com.github.mizosoft.methanol.testing.store
- storeType() - Method in class com.github.mizosoft.methanol.testing.store.StoreConfig
- StringDecoder - Class in com.github.mizosoft.methanol.testing
- StringDecoder() - Constructor for class com.github.mizosoft.methanol.testing.StringDecoder
- submit(T) - Method in class com.github.mizosoft.methanol.internal.flow.AbstractQueueSubscription
- submit(T) - Method in class com.github.mizosoft.methanol.testing.SubmittablePublisher
- submit(T) - Method in class com.github.mizosoft.methanol.testing.SubmittableSubscription
- submitAll(Iterable<T>) - Method in class com.github.mizosoft.methanol.testing.SubmittablePublisher
- submitAndComplete(T) - Method in class com.github.mizosoft.methanol.internal.flow.AbstractQueueSubscription
- submitOnNext(Flow.Subscriber<? super T>, T) - Method in class com.github.mizosoft.methanol.internal.flow.AbstractSubscription
-
Submits given item to the downstream, returning
false
and cancelling on failure. - submitSilently(T) - Method in class com.github.mizosoft.methanol.internal.flow.AbstractQueueSubscription
- submitSilently(T) - Method in class com.github.mizosoft.methanol.testing.SubmittableSubscription
- SubmittablePublisher<T> - Class in com.github.mizosoft.methanol.testing
-
A
Publisher<T>
that emits submitted items. - SubmittablePublisher(Executor) - Constructor for class com.github.mizosoft.methanol.testing.SubmittablePublisher
- SubmittableSubscription<T> - Class in com.github.mizosoft.methanol.testing
-
A subscription that publishes submitted items.
- SubmittableSubscription(Flow.Subscriber<? super T>, Executor) - Constructor for class com.github.mizosoft.methanol.testing.SubmittableSubscription
- subscribe(Flow.Subscriber<? super HttpResponse<T>>) - Method in class com.github.mizosoft.methanol.internal.extensions.HttpResponsePublisher
- subscribe(Flow.Subscriber<? super ByteBuffer>) - Method in class com.github.mizosoft.methanol.FormBodyPublisher
- subscribe(Flow.Subscriber<? super ByteBuffer>) - Method in class com.github.mizosoft.methanol.internal.extensions.ByteBufferBodyPublisher
- subscribe(Flow.Subscriber<? super ByteBuffer>) - Method in class com.github.mizosoft.methanol.internal.extensions.ForwardingBodyPublisher
- subscribe(Flow.Subscriber<? super ByteBuffer>) - Method in class com.github.mizosoft.methanol.internal.extensions.SupplierBodyPublisher
- subscribe(Flow.Subscriber<? super ByteBuffer>) - Method in class com.github.mizosoft.methanol.MultipartBodyPublisher
- subscribe(Flow.Subscriber<? super ByteBuffer>) - Method in class com.github.mizosoft.methanol.WritableBodyPublisher
- subscribe(Flow.Subscriber<? super List<ByteBuffer>>) - Method in class com.github.mizosoft.methanol.internal.cache.CacheReadingPublisher
- subscribe(Flow.Subscriber<? super List<ByteBuffer>>) - Method in class com.github.mizosoft.methanol.internal.cache.CacheWritingPublisher
- subscribe(Flow.Subscriber<? super T>) - Method in class com.github.mizosoft.methanol.testing.EmptyPublisher
- subscribe(Flow.Subscriber<? super T>) - Method in class com.github.mizosoft.methanol.testing.FailingPublisher
- subscribe(Flow.Subscriber<? super T>) - Method in class com.github.mizosoft.methanol.testing.IterablePublisher
- subscribe(Flow.Subscriber<? super T>) - Method in class com.github.mizosoft.methanol.testing.SubmittablePublisher
- subscriberOf(TypeRef<T>, BodyAdapter.Hints) - Method in class com.github.mizosoft.methanol.AdapterCodec
-
Returns a
HttpResponse.BodySubscriber
that decodes the response body into an object of the given type. - subtractAndGetDemand(Object, VarHandle, long) - Static method in class com.github.mizosoft.methanol.internal.flow.FlowSupport
-
Subtracts given count from demand.
- subtype() - Method in class com.github.mizosoft.methanol.MediaType
-
Returns the subtype.
- succeedsWith(String) - Method in class com.github.mizosoft.methanol.testing.verifiers.BodyPublisherVerifier
- succeedsWith(String) - Method in class com.github.mizosoft.methanol.testing.verifiers.EncoderVerifier.ObjectConversionStep
- succeedsWith(String, Charset) - Method in class com.github.mizosoft.methanol.testing.verifiers.BodyPublisherVerifier
- succeedsWith(String, Charset) - Method in class com.github.mizosoft.methanol.testing.verifiers.EncoderVerifier.ObjectConversionStep
- succeedsWith(ByteBuffer) - Method in class com.github.mizosoft.methanol.testing.verifiers.BodyPublisherVerifier
- succeedsWith(ByteBuffer) - Method in class com.github.mizosoft.methanol.testing.verifiers.EncoderVerifier.ObjectConversionStep
- succeedsWith(T) - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.BodySubscriberVerifier
- succeedsWith(T) - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.SupplierVerifier
- succeedsWithNormalizingLineEndings(String) - Method in class com.github.mizosoft.methanol.testing.verifiers.BodyPublisherVerifier
- succeedsWithNormalizingLineEndings(String) - Method in class com.github.mizosoft.methanol.testing.verifiers.EncoderVerifier.ObjectConversionStep
- supplier(ThrowingSupplier<T>) - Static method in class com.github.mizosoft.methanol.internal.function.Unchecked
- SupplierBodyPublisher<T> - Class in com.github.mizosoft.methanol.internal.extensions
- SupplierBodyPublisher(Supplier<T>, Function<T, HttpRequest.BodyPublisher>) - Constructor for class com.github.mizosoft.methanol.internal.extensions.SupplierBodyPublisher
- supplyAsync(ThrowingSupplier<T>, Executor) - Static method in class com.github.mizosoft.methanol.internal.function.Unchecked
- supportedFileAttributeViews() - Method in class com.github.mizosoft.methanol.testing.file.LeakDetectingFileSystem
- supportedFileAttributeViews() - Method in class com.github.mizosoft.methanol.testing.file.WindowsEmulatingFileSystem
- supports(TypeRef<?>) - Method in class com.github.mizosoft.methanol.testing.verifiers.BodyAdapterVerifier
- supports(Class<?>) - Method in class com.github.mizosoft.methanol.testing.verifiers.BodyAdapterVerifier
- supportsParameter(ParameterContext, ExtensionContext) - Method in class com.github.mizosoft.methanol.testing.ExecutorExtension
- supportsParameter(ParameterContext, ExtensionContext) - Method in class com.github.mizosoft.methanol.testing.MockWebServerExtension
- supportsParameter(ParameterContext, ExtensionContext) - Method in class com.github.mizosoft.methanol.testing.store.StoreExtension
- supportsParameter(ParameterContext, ExtensionContext) - Method in class com.github.mizosoft.methanol.testing.TestSubscriberExtension
- supportsType(TypeRef<?>) - Method in class com.github.mizosoft.methanol.adapter.ForwardingBodyAdapter
- supportsType(TypeRef<?>) - Method in interface com.github.mizosoft.methanol.BodyAdapter
-
Returns
true
if this adapter supports the given type. - supportsType(TypeRef<?>) - Method in class com.github.mizosoft.methanol.testing.CharSequenceEncoder
- supportsType(TypeRef<?>) - Method in class com.github.mizosoft.methanol.testing.StringDecoder
- SYNC_EXECUTOR - Static variable in class com.github.mizosoft.methanol.internal.flow.FlowSupport
-
An executor that executes the runnable in the calling thread.
- SYSTEM - Enum constant in enum class com.github.mizosoft.methanol.testing.store.StoreConfig.FileSystemType
- systemDelayer() - Static method in interface com.github.mizosoft.methanol.internal.concurrent.Delayer
-
A Delayer that uses the system-wide scheduler through CompletableFuture::delayedExecutor.
- systemMillisUtc() - Static method in class com.github.mizosoft.methanol.internal.Utils
T
- tag(TypeRef<T>) - Method in class com.github.mizosoft.methanol.TaggableRequest
-
Returns the tag associated with the given type if present.
- tag(TypeRef<T>, T) - Method in class com.github.mizosoft.methanol.MutableRequest
- tag(TypeRef<T>, T) - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
-
Adds a tag mapped to the given type.
- tag(Class<T>) - Method in class com.github.mizosoft.methanol.TaggableRequest
-
Returns the tag associated with the given type if present.
- tag(Class<T>, T) - Method in class com.github.mizosoft.methanol.MutableRequest
- tag(Class<T>, T) - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
-
Adds a tag mapped to the given type.
- tag(Object) - Method in class com.github.mizosoft.methanol.MutableRequest
- tag(Object) - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
-
Adds a tag mapped to the given object's runtime type.
- TaggableRequest - Class in com.github.mizosoft.methanol
-
An
HttpRequest
that can carry arbitrary values, referred to as tags. - TaggableRequest.Builder - Interface in com.github.mizosoft.methanol
-
An
HttpRequest.Builder
that allows attaching tags. - tagOf(HttpRequest, TypeRef<T>) - Static method in class com.github.mizosoft.methanol.TaggableRequest
-
Returns the tag associated with the given type if the given request is a
TaggableRequest
and it has a tag with the given type, otherwise returns an emptyOptional
. - tagOf(HttpRequest, Class<T>) - Static method in class com.github.mizosoft.methanol.TaggableRequest
-
Returns the tag associated with the given type if the given request is a
TaggableRequest
and it has a tag with the given type, otherwise returns an emptyOptional
. - taskCount() - Method in class com.github.mizosoft.methanol.testing.MockDelayer
- taskCount() - Method in class com.github.mizosoft.methanol.testing.MockExecutor
- TestableStore - Interface in com.github.mizosoft.methanol.internal.cache
- tested() - Element in annotation interface com.github.mizosoft.methanol.testing.store.StoreSpec
- TestException - Exception Class in com.github.mizosoft.methanol.testing
- TestException() - Constructor for exception class com.github.mizosoft.methanol.testing.TestException
- TestSubscriber<T> - Class in com.github.mizosoft.methanol.testing
-
A
Flow.Subscriber
implementation that facilitates testingFlow.Publisher
implementations and the like. - TestSubscriber() - Constructor for class com.github.mizosoft.methanol.testing.TestSubscriber
- TestSubscriberContext - Class in com.github.mizosoft.methanol.testing
-
Creates and manages
TestSubscriber
instances. - TestSubscriberContext() - Constructor for class com.github.mizosoft.methanol.testing.TestSubscriberContext
- TestSubscriberExtension - Class in com.github.mizosoft.methanol.testing
-
Extension
that providesTestSubscriber
orTestSubscriberContext
instances and reports misbehaving usage of the provided subscribers, according to the reactive-streams protocol. - TestSubscriberExtension() - Constructor for class com.github.mizosoft.methanol.testing.TestSubscriberExtension
- TestSubscription - Class in com.github.mizosoft.methanol.testing
- TestSubscription() - Constructor for class com.github.mizosoft.methanol.testing.TestSubscription
- TestUtils - Class in com.github.mizosoft.methanol.testing
- TEXT_ANY - Static variable in class com.github.mizosoft.methanol.MediaType
-
text
/*
- TEXT_HTML - Static variable in class com.github.mizosoft.methanol.MediaType
-
text/html
- TEXT_MARKDOWN - Static variable in class com.github.mizosoft.methanol.MediaType
-
text/markdown
- TEXT_PLAIN - Static variable in class com.github.mizosoft.methanol.MediaType
-
text/plain
- TEXT_XML - Static variable in class com.github.mizosoft.methanol.MediaType
-
text/xml
- textPart(String, Object) - Method in class com.github.mizosoft.methanol.MultipartBodyPublisher.Builder
-
Adds a
text/plain
form field with the given name and value. - textPart(String, Object, Charset) - Method in class com.github.mizosoft.methanol.MultipartBodyPublisher.Builder
-
Adds a
text/plain
form field with the given name and value, using the given charset for encoding the field's value. - ThrowingBiConsumer<T,
U> - Interface in com.github.mizosoft.methanol.internal.function - ThrowingConsumer<T> - Interface in com.github.mizosoft.methanol.function
-
A consumer that permits throwing a checked
Exception
. - ThrowingFunction<T,
R> - Interface in com.github.mizosoft.methanol.internal.function -
A
Function
that may throw a checked exception. - ThrowingRunnable - Interface in com.github.mizosoft.methanol.internal.function
-
A
Runnable
that may throw a checked exception. - ThrowingSupplier<T> - Interface in com.github.mizosoft.methanol.internal.function
-
A
Supplier
that may throw a checked exception. - throwOnNext(boolean) - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- throwOnSubscribe(boolean) - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- throwOnSubscribeAndOnNext(boolean) - Method in class com.github.mizosoft.methanol.testing.TestSubscriber
- timeout() - Method in class com.github.mizosoft.methanol.MutableRequest
- timeout(Duration) - Method in class com.github.mizosoft.methanol.MutableRequest
- timeout(Duration) - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
- TIMEOUT_SECONDS - Static variable in class com.github.mizosoft.methanol.testing.TestUtils
- TimeoutBodySubscriber<T> - Class in com.github.mizosoft.methanol.internal.extensions
- TimeoutBodySubscriber(HttpResponse.BodySubscriber<T>, Duration, Delayer) - Constructor for class com.github.mizosoft.methanol.internal.extensions.TimeoutBodySubscriber
- timeoutError(long, Duration) - Method in class com.github.mizosoft.methanol.internal.extensions.TimeoutBodySubscriber
- timeoutError(long, Duration) - Method in class com.github.mizosoft.methanol.internal.flow.TimeoutSubscriber
- TimeoutSubscriber<T,
S> - Class in com.github.mizosoft.methanol.internal.flow -
A subscriber that intercepts requests to upstream and schedules error completion if each requested item isn't received within a timeout.
- TimeoutSubscriber(S, Duration, Delayer) - Constructor for class com.github.mizosoft.methanol.internal.flow.TimeoutSubscriber
- timePassed() - Method in interface com.github.mizosoft.methanol.ProgressTracker.Progress
-
Returns the time passed between this and the previous progress events.
- timePassedThreshold() - Method in class com.github.mizosoft.methanol.ProgressTracker
-
Returns the minimum time to pass for a progress event to be signalled.
- timePassedThreshold(Duration) - Method in class com.github.mizosoft.methanol.ProgressTracker.Builder
-
Sets the minimum amount of time to pass for a progress event to be signalled.
- timeRequestSent() - Method in interface com.github.mizosoft.methanol.TrackedResponse
-
Returns the time the request resulting in this response was sent.
- timeRequestSent(Instant) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- timeResponseReceived() - Method in interface com.github.mizosoft.methanol.TrackedResponse
-
Returns the time this response was received.
- timeResponseReceived(Instant) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- to(TypeRef<T>) - Method in interface com.github.mizosoft.methanol.ResponsePayload
-
Converts this payload into an object of (possibly generic) type
T
. - to(Class<T>) - Method in interface com.github.mizosoft.methanol.ResponsePayload
-
Converts this payload into an object of type
T
. - toAsync(TypeRef<T>) - Method in interface com.github.mizosoft.methanol.ResponsePayload
-
Asynchronously converts this payload into an object of (possibly generic) type
T
. - toAsync(Class<T>) - Method in interface com.github.mizosoft.methanol.ResponsePayload
-
Asynchronously converts this payload into an object of type
T
. - toBody(Object, MediaType) - Method in interface com.github.mizosoft.methanol.adapter.AbstractBodyAdapter.BaseEncoder
-
Returns a
HttpRequest.BodyPublisher
that encodes the given object into a request body using the format specified by the given media type. - toBody(Object, MediaType) - Method in class com.github.mizosoft.methanol.adapter.ForwardingEncoder
- toBody(Object, MediaType) - Method in interface com.github.mizosoft.methanol.BodyAdapter.Encoder
-
Returns a
HttpRequest.BodyPublisher
that encodes the given object into a request body using the format specified by the given media type. - toBody(Object, MediaType) - Method in class com.github.mizosoft.methanol.testing.CharSequenceEncoder
- toBody(T, TypeRef<T>, BodyAdapter.Hints) - Method in interface com.github.mizosoft.methanol.adapter.AbstractBodyAdapter.BaseEncoder
- toBody(T, TypeRef<T>, BodyAdapter.Hints) - Method in class com.github.mizosoft.methanol.adapter.ForwardingEncoder
- toBody(T, TypeRef<T>, BodyAdapter.Hints) - Method in interface com.github.mizosoft.methanol.BodyAdapter.Encoder
-
Returns a
HttpRequest.BodyPublisher
that encodes the given object into a request body based on the givenTypeRef
, using the given hintsBodyAdapter.Hints
for encoder-specific customization. - toByteArray() - Method in class com.github.mizosoft.methanol.testing.MockGzipStream
- toByteArray(ByteBuffer) - Static method in class com.github.mizosoft.methanol.testing.TestUtils
- toCompletionException(Throwable) - Static method in class com.github.mizosoft.methanol.internal.Utils
- toDeferredObject(TypeRef<T>, MediaType) - Method in interface com.github.mizosoft.methanol.adapter.AbstractBodyAdapter.BaseDecoder
-
Returns a completed
HttpResponse.BodySubscriber
that lazily decodes the response body into an object of the given type using the format specified by the given media type. - toDeferredObject(TypeRef<T>, MediaType) - Method in class com.github.mizosoft.methanol.adapter.ForwardingDecoder
- toDeferredObject(TypeRef<T>, MediaType) - Method in interface com.github.mizosoft.methanol.BodyAdapter.Decoder
-
Returns a completed
HttpResponse.BodySubscriber
that lazily decodes the response body into an object of the given type using the format specified by the given media type. - toDeferredObject(TypeRef<T>, BodyAdapter.Hints) - Method in interface com.github.mizosoft.methanol.adapter.AbstractBodyAdapter.BaseDecoder
-
Returns a completed
HttpResponse.BodySubscriber
that lazily decodes the response body into an object of the given type using the givenBodyAdapter.Hints
. - toDeferredObject(TypeRef<T>, BodyAdapter.Hints) - Method in class com.github.mizosoft.methanol.adapter.ForwardingDecoder
- toDeferredObject(TypeRef<T>, BodyAdapter.Hints) - Method in interface com.github.mizosoft.methanol.BodyAdapter.Decoder
-
Returns a completed
HttpResponse.BodySubscriber
that lazily decodes the response body into an object of the given type using the givenBodyAdapter.Hints
. - TODO() - Static method in class com.github.mizosoft.methanol.internal.Validate
- toImmutableRequest() - Method in class com.github.mizosoft.methanol.MutableRequest
-
Returns an immutable copy of this request.
- toInterruptedIOException(InterruptedException) - Static method in class com.github.mizosoft.methanol.internal.Utils
- TOKEN_MATCHER - Static variable in class com.github.mizosoft.methanol.internal.text.HttpCharMatchers
- tokenizeToLists(ByteBuffer, int[], int[]) - Static method in class com.github.mizosoft.methanol.testing.BufferTokenizer
- toMap() - Method in interface com.github.mizosoft.methanol.BodyAdapter.Hints
-
Returns an immutable map of all hints.
- toObject(TypeRef<T>, MediaType) - Method in interface com.github.mizosoft.methanol.adapter.AbstractBodyAdapter.BaseDecoder
-
Returns a
HttpResponse.BodySubscriber
that decodes the response body into an object of the given type using the format specified by the given media type. - toObject(TypeRef<T>, MediaType) - Method in class com.github.mizosoft.methanol.adapter.ForwardingDecoder
- toObject(TypeRef<T>, MediaType) - Method in interface com.github.mizosoft.methanol.BodyAdapter.Decoder
-
Returns a
HttpResponse.BodySubscriber
that decodes the response body into an object of the given type using the format specified by the given media type. - toObject(TypeRef<T>, MediaType) - Method in class com.github.mizosoft.methanol.testing.StringDecoder
- toObject(TypeRef<T>, BodyAdapter.Hints) - Method in interface com.github.mizosoft.methanol.adapter.AbstractBodyAdapter.BaseDecoder
- toObject(TypeRef<T>, BodyAdapter.Hints) - Method in class com.github.mizosoft.methanol.adapter.ForwardingDecoder
- toObject(TypeRef<T>, BodyAdapter.Hints) - Method in interface com.github.mizosoft.methanol.BodyAdapter.Decoder
-
Returns a
HttpResponse.BodySubscriber
that decodes the response body into an object of the given type using the givenBodyAdapter.Hints
. - toPublisherChain(Methanol.Interceptor.Chain<T>, Executor) - Static method in class com.github.mizosoft.methanol.internal.extensions.Handlers
- toResponseBuilder() - Method in class com.github.mizosoft.methanol.internal.cache.CacheResponseMetadata
- toString() - Method in class com.github.mizosoft.methanol.CacheControl
- toString() - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore.Hash
- toString() - Method in class com.github.mizosoft.methanol.internal.concurrent.SerialExecutor
- toString() - Method in class com.github.mizosoft.methanol.MediaType
-
Returns a text representation of this media type that is compatible with the value of the
Content-Type
header. - toString() - Method in class com.github.mizosoft.methanol.MutableRequest
- toString() - Method in interface com.github.mizosoft.methanol.ProgressTracker.Progress
- toString() - Method in class com.github.mizosoft.methanol.testing.MockExecutor
- toString() - Method in class com.github.mizosoft.methanol.testing.store.RedisClusterSession
- toString() - Method in class com.github.mizosoft.methanol.testing.store.RedisStandaloneSession
- toString() - Method in class com.github.mizosoft.methanol.TypeRef
-
Returns a string representation for the type.
- totalBytesTransferred() - Method in interface com.github.mizosoft.methanol.ProgressTracker.Progress
-
Returns the total number of bytes transferred so far.
- totalTimePassed() - Method in interface com.github.mizosoft.methanol.ProgressTracker.Progress
-
Returns the total time passed since the upload or download operation has begun.
- toUnchecked() - Method in interface com.github.mizosoft.methanol.function.ThrowingConsumer
- toUnchecked() - Method in interface com.github.mizosoft.methanol.internal.function.ThrowingBiConsumer
- toUnchecked() - Method in interface com.github.mizosoft.methanol.internal.function.ThrowingFunction
- toUnchecked() - Method in interface com.github.mizosoft.methanol.internal.function.ThrowingRunnable
- toUnchecked() - Method in interface com.github.mizosoft.methanol.internal.function.ThrowingSupplier
- TrackedResponse<T> - Interface in com.github.mizosoft.methanol
-
A response with recorded send/receive timestamps.
- tracking(HttpRequest.BodyPublisher, ProgressTracker.Listener) - Method in class com.github.mizosoft.methanol.ProgressTracker
-
Returns a
BodyPublisher
that tracks the givenBodyPublisher
's upload progress. - tracking(HttpResponse.BodyHandler<T>, ProgressTracker.Listener) - Method in class com.github.mizosoft.methanol.ProgressTracker
-
Returns a
BodyHandler
that tracks the download progress of theBodySubscriber
returned by the given handler. - tracking(HttpResponse.BodySubscriber<T>, ProgressTracker.Listener, long) - Method in class com.github.mizosoft.methanol.ProgressTracker
-
Returns a
BodySubscriber
that tracks the givenBodySubscriber
's download progress. - trackingMultipart(MultipartBodyPublisher, ProgressTracker.MultipartListener) - Method in class com.github.mizosoft.methanol.ProgressTracker
-
Returns a
BodyPublisher
that tracks the givenMultipartBodyPublisher
's upload progress with per-part progress events. - transferFrom(ReadableByteChannel, long, long) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- transferTo(long, long, WritableByteChannel) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- truncate(long) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingAsynchronousFileChannel
- truncate(long) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- TRUNCATED_SHA_256 - Static variable in interface com.github.mizosoft.methanol.internal.cache.DiskStore.Hasher
-
A Hasher returning the first 80 bits of the SHA-256 of the key's UTF-8 encoded bytes.
- tryLock(long, long, boolean) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingAsynchronousFileChannel
- tryLock(long, long, boolean) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- type() - Method in class com.github.mizosoft.methanol.MediaType
-
Returns the general type.
- type() - Method in class com.github.mizosoft.methanol.TypeRef
-
Returns the underlying
Type
. - typeArgumentAt(int) - Method in class com.github.mizosoft.methanol.TypeRef
-
Returns the type argument of
TypeRef
at the given index, provided thatT
is aparameterized type
that has at least as many arguments as the given index. - typeArguments() - Method in class com.github.mizosoft.methanol.TypeRef
-
Returns a list of
TypeRef<?>
corresponding toTypeRef
's type arguments, provided it is aparameterized type
, otherwise an empty list is returned. - TypeRef<T> - Class in com.github.mizosoft.methanol
- TypeRef() - Constructor for class com.github.mizosoft.methanol.TypeRef
U
- Unchecked - Class in com.github.mizosoft.methanol.internal.function
-
Static functions that make it easier to mix checked exceptions with lambdas.
- uncheckedCast(Object) - Method in class com.github.mizosoft.methanol.TypeRef
- UncheckedJaxbException - Exception Class in com.github.mizosoft.methanol.adapter.jaxb.jakarta
-
Unchecked wrapper over a
JAXBException
. - UncheckedJaxbException - Exception Class in com.github.mizosoft.methanol.adapter.jaxb
-
Unchecked wrapper over a
JAXBException
. - UncheckedJaxbException(JAXBException) - Constructor for exception class com.github.mizosoft.methanol.adapter.jaxb.jakarta.UncheckedJaxbException
-
Creates a new
UncheckedJaxbException
with the given cause. - UncheckedJaxbException(JAXBException) - Constructor for exception class com.github.mizosoft.methanol.adapter.jaxb.UncheckedJaxbException
-
Creates a new
UncheckedJaxbException
with the given cause. - underlyingClient() - Method in class com.github.mizosoft.methanol.Methanol
-
Returns the underlying
HttpClient
used for sending requests. - UNSATISFIABLE - Enum constant in enum class com.github.mizosoft.methanol.CacheAwareResponse.CacheStatus
-
The response was generated by the cache to serve an unsatisfiable request that prohibited network use despite being necessary to serve a valid response.
- update(CacheResponse) - Method in interface com.github.mizosoft.methanol.internal.cache.LocalCache
- update(Upstream) - Method in class com.github.mizosoft.methanol.internal.flow.Prefetcher
- upstream - Variable in class com.github.mizosoft.methanol.internal.flow.ForwardingSubscriber
- upstream() - Method in class com.github.mizosoft.methanol.internal.extensions.ForwardingBodyPublisher
- Upstream - Class in com.github.mizosoft.methanol.internal.flow
-
A one-use atomic reference to an upstream subscription.
- Upstream() - Constructor for class com.github.mizosoft.methanol.internal.flow.Upstream
- uri() - Method in class com.github.mizosoft.methanol.internal.cache.CacheResponseMetadata
- uri() - Method in class com.github.mizosoft.methanol.MutableRequest
- uri() - Method in class com.github.mizosoft.methanol.testing.HttpResponseStub
- uri() - Method in class com.github.mizosoft.methanol.testing.store.RedisStandaloneSession
- uri(String) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Sets this request's
URI
. - uri(URI) - Method in class com.github.mizosoft.methanol.MutableRequest
-
Sets this request's
URI
. - uri(URI) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- uri(URI) - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
- uris() - Method in class com.github.mizosoft.methanol.HttpCache
-
Returns an iterator over the
URIs
of responses known to this cache. - uris() - Method in class com.github.mizosoft.methanol.testing.store.RedisClusterSession
- userAgent() - Method in class com.github.mizosoft.methanol.Methanol
-
Returns this client's
User-Agent
. - userAgent(String) - Method in class com.github.mizosoft.methanol.Methanol.BaseBuilder
-
Sets a default
User-Agent
header to use when sending requests. - Utils - Class in com.github.mizosoft.methanol.internal
-
Miscellaneous utilities.
V
- Validate - Class in com.github.mizosoft.methanol.internal
- value() - Method in interface com.github.mizosoft.methanol.ProgressTracker.Progress
-
Returns a double between
0
and1
indicating progress, orDouble.NaN
if notProgressTracker.Progress.determinate()
. - value() - Element in annotation interface com.github.mizosoft.methanol.testing.ExecutorExtension.ExecutorSpec
- value() - Element in annotation interface com.github.mizosoft.methanol.testing.RepeatArguments
- valueOf(String) - Static method in enum class com.github.mizosoft.methanol.CacheAwareResponse.CacheStatus
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.github.mizosoft.methanol.testing.decoder.Decode.BufferSizeOption
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.github.mizosoft.methanol.testing.ExecutorExtension.ExecutorType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.github.mizosoft.methanol.testing.MockGzipStream.CorruptionMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.github.mizosoft.methanol.testing.store.StoreConfig.Execution
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.github.mizosoft.methanol.testing.store.StoreConfig.FileSystemType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.github.mizosoft.methanol.testing.store.StoreConfig.StoreType
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class com.github.mizosoft.methanol.CacheAwareResponse.CacheStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.github.mizosoft.methanol.testing.decoder.Decode.BufferSizeOption
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.github.mizosoft.methanol.testing.ExecutorExtension.ExecutorType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.github.mizosoft.methanol.testing.MockGzipStream.CorruptionMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.github.mizosoft.methanol.testing.store.StoreConfig.Execution
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.github.mizosoft.methanol.testing.store.StoreConfig.FileSystemType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.github.mizosoft.methanol.testing.store.StoreConfig.StoreType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- varyFields(HttpHeaders) - Static method in class com.github.mizosoft.methanol.internal.cache.CacheResponseMetadata
- Verifiers - Class in com.github.mizosoft.methanol.testing.verifiers
- verifyThat(BodyAdapter.Decoder) - Static method in class com.github.mizosoft.methanol.testing.verifiers.Verifiers
- verifyThat(BodyAdapter.Encoder) - Static method in class com.github.mizosoft.methanol.testing.verifiers.Verifiers
- verifyThat(HttpRequest) - Static method in class com.github.mizosoft.methanol.testing.verifiers.Verifiers
- verifyThat(HttpRequest.BodyPublisher) - Static method in class com.github.mizosoft.methanol.testing.verifiers.Verifiers
- verifyThat(HttpResponse.BodySubscriber<T>) - Static method in class com.github.mizosoft.methanol.testing.verifiers.Verifiers
- verifyThat(HttpResponse<T>) - Static method in class com.github.mizosoft.methanol.testing.verifiers.Verifiers
- version() - Method in class com.github.mizosoft.methanol.internal.extensions.ImmutableResponseInfo
- version() - Method in class com.github.mizosoft.methanol.Methanol
- version() - Method in class com.github.mizosoft.methanol.MutableRequest
- version() - Method in class com.github.mizosoft.methanol.testing.HttpClientStub
- version() - Method in class com.github.mizosoft.methanol.testing.HttpResponseStub
- version() - Method in class com.github.mizosoft.methanol.testing.ImmutableResponseInfo
- version() - Method in class com.github.mizosoft.methanol.testing.RecordingHttpClient
- version(HttpClient.Version) - Method in class com.github.mizosoft.methanol.Methanol.Builder
- version(HttpClient.Version) - Method in class com.github.mizosoft.methanol.MutableRequest
- version(HttpClient.Version) - Method in class com.github.mizosoft.methanol.ResponseBuilder
- version(HttpClient.Version) - Method in interface com.github.mizosoft.methanol.TaggableRequest.Builder
- VERY_SLOW_TIMEOUT_SECONDS - Static variable in class com.github.mizosoft.methanol.testing.TestUtils
- view(Store, String) - Static method in class com.github.mizosoft.methanol.testing.store.StoreTesting
- view(String) - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore
- view(String) - Method in class com.github.mizosoft.methanol.internal.cache.MemoryStore
- view(String) - Method in interface com.github.mizosoft.methanol.internal.cache.Store
-
Synchronous variant of
Store.view(String, Executor)
. - view(String, Executor) - Method in class com.github.mizosoft.methanol.internal.cache.DiskStore
- view(String, Executor) - Method in class com.github.mizosoft.methanol.internal.cache.MemoryStore
- view(String, Executor) - Method in interface com.github.mizosoft.methanol.internal.cache.Store
-
Opens a viewer for the entry associated with the given key.
W
- WindowsEmulatingFileSystem - Class in com.github.mizosoft.methanol.testing.file
-
A
ForwardingFileSystem
that emulates Windows' behaviour regarding the deletion of files with open handles. - with(HttpResponse.BodyHandler<U>, HttpResponse.PushPromiseHandler<U>) - Method in interface com.github.mizosoft.methanol.Methanol.Interceptor.Chain
-
Returns a new chain that uses given handlers, possibly targeting another response type.
- with(Consumer<ResponseBuilder<?>>) - Method in class com.github.mizosoft.methanol.internal.cache.CacheResponse
- with(Consumer<ResponseBuilder<?>>) - Method in class com.github.mizosoft.methanol.internal.cache.NetworkResponse
- with(Consumer<ResponseBuilder<?>>) - Method in class com.github.mizosoft.methanol.internal.cache.RawResponse
- with(UnaryOperator<HttpResponse.BodyHandler<T>>) - Method in interface com.github.mizosoft.methanol.Methanol.Interceptor.Chain
-
Returns a new chain after applying the given function to this chain's body handler.
- with(UnaryOperator<HttpResponse.BodyHandler<T>>, UnaryOperator<HttpResponse.PushPromiseHandler<T>>) - Method in interface com.github.mizosoft.methanol.Methanol.Interceptor.Chain
-
Returns a new chain after applying the given functions to this chain's body and push promise handlers, and only to the latter if a push promise handler is present.
- withBody(String) - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.BodyConversionStep
- withBody(String, Charset) - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.BodyConversionStep
- withBody(ByteBuffer) - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.BodyConversionStep
- withBodyHandler(HttpResponse.BodyHandler<T>) - Method in interface com.github.mizosoft.methanol.Methanol.Interceptor.Chain
-
Returns a new chain that uses the given
BodyHandler
. - withCacheHeaders() - Method in class com.github.mizosoft.methanol.internal.cache.CacheResponse
-
Add the additional cache headers advised by rfc7234 like Age and Warning.
- withCharset(Charset) - Method in class com.github.mizosoft.methanol.MediaType
-
Returns a new
MediaType
with this instance's type, subtype and parameters but with the name of the given charset as the value of the charset parameter. - withDeferredBody(String) - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.BodyConversionStep
- withDeferredBody(String, Charset) - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.BodyConversionStep
- withDeferredBody(ByteBuffer) - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.BodyConversionStep
- withDeferredFailure(Throwable) - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.BodyConversionStep
- withFailure(Throwable) - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.BodyConversionStep
- withinClosedRange(int, int) - Static method in interface com.github.mizosoft.methanol.internal.text.CharMatcher
- withMediaType(MediaType) - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.BodyConversionStep
- withMediaType(MediaType) - Method in class com.github.mizosoft.methanol.testing.verifiers.EncoderVerifier.ObjectConversionStep
- withMediaType(String) - Method in class com.github.mizosoft.methanol.testing.verifiers.DecoderVerifier.BodyConversionStep
- withMediaType(String) - Method in class com.github.mizosoft.methanol.testing.verifiers.EncoderVerifier.ObjectConversionStep
- withParameter(String, String) - Method in class com.github.mizosoft.methanol.MediaType
-
Returns a new
MediaType
with this instance's type, subtype and parameters but with the value of the parameter specified by the given name set to the given value. - withParameters(Map<String, String>) - Method in class com.github.mizosoft.methanol.MediaType
-
Returns a new
MediaType
with this instance's type, subtype and parameters but with each of the given parameters' names set to their corresponding values. - withPushPromiseHandler(HttpResponse.PushPromiseHandler<T>) - Method in interface com.github.mizosoft.methanol.Methanol.Interceptor.Chain
-
Returns a new chain that uses the given
PushPromiseHandler
. - withReadTimeout(HttpResponse.BodyHandler<T>, Duration) - Static method in class com.github.mizosoft.methanol.MoreBodyHandlers
-
Returns a
BodyHandler
that returns a subscriber obtained fromMoreBodySubscribers.withReadTimeout(BodySubscriber, Duration)
. - withReadTimeout(HttpResponse.BodyHandler<T>, Duration, ScheduledExecutorService) - Static method in class com.github.mizosoft.methanol.MoreBodyHandlers
-
Returns a
BodyHandler
that returns a subscriber obtained fromMoreBodySubscribers.withReadTimeout(BodySubscriber, Duration, ScheduledExecutorService)
. - withReadTimeout(HttpResponse.BodySubscriber<T>, Duration) - Static method in class com.github.mizosoft.methanol.MoreBodySubscribers
-
Returns a
BodySubscriber
that completes the given downstream withHttpReadTimeoutException
if a requested signal is not received within the given timeout. - withReadTimeout(HttpResponse.BodySubscriber<T>, Duration, ScheduledExecutorService) - Static method in class com.github.mizosoft.methanol.MoreBodySubscribers
-
Returns a
BodySubscriber
that completes the given downstream withHttpReadTimeoutException
if a requested signal is not received within the given timeout. - withZone(ZoneId) - Method in class com.github.mizosoft.methanol.testing.MockClock
- wrap(FileSystem) - Static method in class com.github.mizosoft.methanol.testing.file.LeakDetectingFileSystem
- wrap(FileSystem) - Static method in class com.github.mizosoft.methanol.testing.file.WindowsEmulatingFileSystem
- WritableBodyPublisher - Class in com.github.mizosoft.methanol
-
A
BodyPublisher
that allows streaming the body's content through anOutputStream
or aWritableByteChannel
. - write(Store.Editor, String) - Static method in class com.github.mizosoft.methanol.testing.store.StoreTesting
- write(Store.EntryWriter, String) - Static method in class com.github.mizosoft.methanol.testing.store.StoreTesting
- write(Store, String, String, String) - Static method in class com.github.mizosoft.methanol.testing.store.StoreTesting
- write(ByteBuffer) - Method in interface com.github.mizosoft.methanol.internal.cache.Store.EntryWriter
-
Synchronous variant of
Store.EntryWriter.write(ByteBuffer, Executor)
. - write(ByteBuffer) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- write(ByteBuffer[], int, int) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- write(ByteBuffer, long) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingAsynchronousFileChannel
- write(ByteBuffer, long) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingFileChannel
- write(ByteBuffer, long, A, CompletionHandler<Integer, ? super A>) - Method in class com.github.mizosoft.methanol.testing.file.ForwardingAsynchronousFileChannel
- write(ByteBuffer, Executor) - Method in interface com.github.mizosoft.methanol.internal.cache.Store.EntryWriter
-
Writes all the bytes from the given buffer into the editor's data stream, and returns the number of bytes actually written.
- write(List<ByteBuffer>) - Method in interface com.github.mizosoft.methanol.internal.cache.Store.EntryWriter
-
Synchronous variant of
Store.EntryWriter.write(List, Executor)
. - write(List<ByteBuffer>, Executor) - Method in interface com.github.mizosoft.methanol.internal.cache.Store.EntryWriter
-
Writes all the bytes from the given buffers into the editor's data stream, in sequential order, and returns the number of bytes actually written.
- writeFailureCount() - Method in interface com.github.mizosoft.methanol.HttpCache.Stats
-
Returns the number of times a response wasn't written to cache due to a write failure.
- writer() - Method in interface com.github.mizosoft.methanol.internal.cache.Store.Editor
-
Returns the writer associated with this editor, which is at most one.
- writeSuccessCount() - Method in interface com.github.mizosoft.methanol.HttpCache.Stats
-
Returns the number of times a response was successfully written to cache.
- writingWith(Store.Editor, Executor, CacheWritingPublisher.Listener) - Method in class com.github.mizosoft.methanol.internal.cache.NetworkResponse
Z
- zlibUnwrap(byte[]) - Static method in class com.github.mizosoft.methanol.testing.TestUtils
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
JacksonAdapterFactory.createJsonDecoder()
.