Uses of Interface
io.helidon.common.reactive.Single
-
Packages that use Single Package Description io.helidon.common.http HTTP APIs and implementations usable by both server and client side of the HTTP story.io.helidon.common.reactive Common reactive library for Helidon projects.io.helidon.dbclient Reactive Database API for Helidon.io.helidon.dbclient.common Helper classes to use in various implementations.io.helidon.dbclient.mongodb Helidon DB integration for reactive mongoDB.io.helidon.dbclient.tracing Tracing support for Helidon DB.io.helidon.faulttolerance Fault tolerance for Helidon SE reactive implementation.io.helidon.integrations.common.rest Common classes for accessing JSON based REST APIs of third party systems.io.helidon.integrations.oci.atp OCI ATP integration.io.helidon.integrations.oci.connect Classes needed for OCI to connect to service API.io.helidon.integrations.oci.objectstorage OCI Object Storage integration.io.helidon.integrations.oci.telemetry Integration with OCI Telemetry.io.helidon.integrations.oci.vault Integration with OCI Vault REST API including the KMS encryption and digest support.io.helidon.integrations.vault Vault integration.io.helidon.integrations.vault.auths.approle AppRole authentication method for Vault.io.helidon.integrations.vault.auths.common Common classes for Vault integration.io.helidon.integrations.vault.auths.k8s Vault authentication method for Kubernetes.io.helidon.integrations.vault.auths.token Token authentication method for Vault.io.helidon.integrations.vault.secrets.cubbyhole Cubbyhole secret engine support for Vault.io.helidon.integrations.vault.secrets.database Vault's Database Secrets Engine support.io.helidon.integrations.vault.secrets.kv1 Vault's KV1 Secrets Engine support.io.helidon.integrations.vault.secrets.kv2 Vault's Key/value version 2 Secrets Engine support.io.helidon.integrations.vault.secrets.pki Vault's PKI Secrets Engine support.io.helidon.integrations.vault.secrets.transit Vault transit secrets.io.helidon.integrations.vault.sys Sys operations for Vault.io.helidon.lra.coordinator.client MicroProfile Long Running Actions Coordinator client spi.io.helidon.lra.coordinator.client.narayana MicroProfile Long Running Actions Narayana Coordinator client.io.helidon.media.common Common classes for processing content with a specificMediaType
.io.helidon.media.multipart Helidon Media MultiPart.io.helidon.security Securityio.helidon.security.providers.config.vault Vault operation backed by configuration.io.helidon.security.providers.idcs.mapper Mapper that retrieves roles from IDCS server and maps them to user subject.io.helidon.security.providers.oidc.common Open ID Connect (OIDC) classes usable from all OIDC related components.io.helidon.security.spi Security component's SPI.io.helidon.webclient A reactive client for rest calls.io.helidon.webclient.context.propagation Propagation of context values across network using HTTP Headers.io.helidon.webclient.metrics Client metrics service.io.helidon.webclient.security Client service propagation service.io.helidon.webclient.spi This package provides extensibility for theWebClient
.io.helidon.webclient.tracing Client tracing propagation service.io.helidon.webserver Reactive web server API. -
-
Uses of Single in io.helidon.common.http
Methods in io.helidon.common.http that return Single Modifier and Type Method Description <T> Single<T>
Content. as(Class<T> type)
Deprecated.Consumes and converts the request content into a completion stage of the requested type. -
Uses of Single in io.helidon.common.reactive
Classes in io.helidon.common.reactive that implement Single Modifier and Type Class Description class
CompletionSingle<T>
Single as CompletionStage.Methods in io.helidon.common.reactive that return Single Modifier and Type Method Description Single<T>
CompletionSingle. cancel()
default Single<T>
Single. cancel()
Cancel upstream.default <U> Single<U>
Multi. collect(Collector<T,U> collector)
default <U> Single<U>
Multi. collect(Supplier<? extends U> collectionSupplier, BiConsumer<U,T> accumulator)
default Single<List<T>>
Multi. collectList()
default <A,R>
Single<R>Multi. collectStream(Collector<T,A,R> collector)
Collects up upstream items with the help of a the callbacks of aCollector
.default <U> Single<U>
Single. compose(Function<? super Single<T>,? extends Single<? extends U>> composer)
Apply the givencomposer
function to the currentSingle
instance and return theSingle
returned by this function.static <T> Single<T>
Single. create(Single<T> single)
static <T> Single<T>
Single. create(CompletionStage<T> completionStage)
Wrap a CompletionStage into a Multi and signal its outcome non-blockingly.static <T> Single<T>
Single. create(CompletionStage<T> completionStage, boolean nullMeansEmpty)
Wrap a CompletionStage into a Multi and signal its outcome non-blockingly.static <T> Single<T>
Single. create(Flow.Publisher<T> source)
Create aSingle
instance that publishes the first and only item received from the given publisher.static <T> Single<T>
Single. create(Supplier<? extends T> supplier)
Create aSingle
instance that publishes result of the given supplier to its subscriber(s).default Single<T>
Single. defaultIfEmpty(Supplier<? extends T> supplier)
Signals the default item supplied by specified supplier if the upstream is empty.default Single<T>
Single. defaultIfEmpty(T defaultItem)
Signals the default item if the upstream is empty.static <T> Single<T>
Single. defer(Supplier<? extends Single<? extends T>> supplier)
Call the given supplier function for each individual downstream Subscriber to return a Flow.Publisher to subscribe to.static <T> Single<T>
Single. empty()
Get aSingle
instance that completes immediately.static <T> Single<T>
Single. error(Throwable error)
Create aSingle
instance that reports the given given exception to its subscriber(s).default Single<T>
Multi. first()
default <U> Single<U>
Single. flatMapCompletionStage(Function<? super T,? extends CompletionStage<? extends U>> mapper)
Transforms item with supplied function and flatten resultingCompletionStage
result to downstream.default <U> Single<U>
Single. flatMapOptional(Function<? super T,Optional<? extends U>> mapper)
Transform item with supplied function and flatten resultingOptional
to downstream as Single with its value as item if present or empty Single.default <U> Single<U>
Single. flatMapSingle(Function<? super T,? extends Single<? extends U>> mapper)
Transforms item with supplied function and flatten resultingSingle
to downstream.default Single<Void>
Multi. forEach(Consumer<? super T> consumer)
Terminal stage, invokes provided consumer for every item in the stream.static <T> Single<T>
Single. from(Single<T> single)
Deprecated.usecreate(io.helidon.common.reactive.Single)
insteadstatic <T> Single<T>
Single. from(CompletionStage<T> completionStage)
Deprecated.usecreate(java.util.concurrent.CompletionStage)
insteadstatic <T> Single<T>
Single. from(CompletionStage<T> completionStage, boolean nullMeansEmpty)
Deprecated.static <T> Single<T>
Single. from(Flow.Publisher<T> source)
Deprecated.usecreate(java.util.concurrent.Flow.Publisher)
insteaddefault Single<T>
Single. ifEmpty(Runnable ifEmpty)
Executes givenRunnable
when stream is finished without value(empty stream).default Single<Void>
Multi. ignoreElements()
Terminal stage, ignore all items and complete returnedSingle<Void>
successfully or exceptionally.static <T> Single<T>
Single. just(T item)
Create aSingle
instance that publishes the given item to its subscriber(s).default Single<T>
Single. log()
Log all signalsonSubscribe
,onNext
,onError
,onComplete
,cancel
andrequest
coming to and from preceding operator.default Single<T>
Single. log(Level level)
Log all signalsonSubscribe
,onNext
,onError
,onComplete
,cancel
andrequest
coming to and from preceding operator.default Single<T>
Single. log(Level level, boolean trace)
Log all signalsonSubscribe
,onNext
,onError
,onComplete
,cancel
andrequest
coming to and from preceding operator.default Single<T>
Single. log(Level level, String loggerName)
Log all signalsonSubscribe
,onNext
,onError
,onComplete
,cancel
andrequest
coming to and from preceding operator.default <U> Single<U>
Single. map(Function<? super T,? extends U> mapper)
static <T> Single<T>
Single. never()
Get aSingle
instance that never completes.default Single<T>
Single. observeOn(Executor executor)
Re-emit the upstream's signals to the downstream on the given executor's thread.Single<T>
CompletionSingle. onCancel(Runnable onCancel)
default Single<T>
Single. onCancel(Runnable onCancel)
Executes givenRunnable
when a cancel signal is received.default Single<T>
Single. onComplete(Runnable onComplete)
Executes givenRunnable
when onComplete signal is received.default Single<T>
Single. onCompleteResumeWithSingle(Function<Optional<T>,? extends Single<? extends T>> onComplete)
Resume stream with supplied single if onComplete signal is intercepted.default Single<T>
Single. onError(Consumer<? super Throwable> onErrorConsumer)
Executes givenConsumer
when onError signal is received.default Single<T>
Single. onErrorResume(Function<? super Throwable,? extends T> onError)
Function
providing one item to be submitted as onNext in case of onError signal is received.default Single<T>
Single. onErrorResumeWithSingle(Function<? super Throwable,? extends Single<? extends T>> onError)
Resume stream from supplied publisher if onError signal is intercepted.default Single<T>
Single. onTerminate(Runnable onTerminate)
Executes givenRunnable
when any of signals onComplete, onCancel or onError is received.default Single<T>
Single. peek(Consumer<? super T> consumer)
Invoke provided consumer for the item in stream.default Single<T>
Multi. reduce(BiFunction<T,T,T> reducer)
Combine subsequent items via a callback function and emit the final value result as a Single.default <R> Single<R>
Multi. reduce(Supplier<? extends R> supplier, BiFunction<R,T,R> reducer)
Combine every upstream item with an accumulator value to produce a new accumulator value and emit the final accumulator value as a Single.default Single<T>
Single. retry(long count)
Retry a failing upstream at most the given number of times before giving up.default Single<T>
Single. retry(BiPredicate<? super Throwable,? super Long> predicate)
Retry a failing upstream if the predicate returns true.default <U> Single<T>
Single. retryWhen(BiFunction<? super Throwable,? super Long,? extends Flow.Publisher<U>> whenFunction)
Retry a failing upstream when the given function returns a publisher that signals an item.default Single<T>
Single. switchIfEmpty(Single<T> other)
Switch to the other Single if the upstream is empty.default <U> Single<T>
Single. takeUntil(Flow.Publisher<U> other)
Relay upstream items until the other source signals an item or completes.default Single<T>
Single. timeout(long timeout, TimeUnit unit, ScheduledExecutorService executor)
Signals aTimeoutException
if the upstream doesn't signal an item, error or completion within the specified time.default Single<T>
Single. timeout(long timeout, TimeUnit unit, ScheduledExecutorService executor, Single<T> fallback)
Switches to a fallback single if the upstream doesn't signal an item, error or completion within the specified time.static Single<Long>
Single. timer(long time, TimeUnit unit, ScheduledExecutorService executor)
Signal 0L and complete the sequence after the given time elapsed.default Single<Optional<T>>
Single. toOptionalSingle()
Methods in io.helidon.common.reactive that return types with arguments of type Single Modifier and Type Method Description Function<? super Multi<ByteBuffer>,? extends Single<Void>>
IoMulti.MultiToByteChannelBuilder. build()
static Function<? super Multi<ByteBuffer>,? extends Single<Void>>
IoMulti. multiToByteChannel(WritableByteChannel writableChannel)
Creates function consumingMulti<ByteBuffer>
to suppliedWritableByteChannel
.Methods in io.helidon.common.reactive with parameters of type Single Modifier and Type Method Description static <T> Multi<T>
Multi. create(Single<T> single)
static <T> Single<T>
Single. create(Single<T> single)
static <T> Multi<T>
Multi. from(Single<T> single)
Deprecated.useMulti.create(io.helidon.common.reactive.Single)
insteadstatic <T> Single<T>
Single. from(Single<T> single)
Deprecated.usecreate(io.helidon.common.reactive.Single)
insteaddefault Single<T>
Single. switchIfEmpty(Single<T> other)
Switch to the other Single if the upstream is empty.default Single<T>
Single. timeout(long timeout, TimeUnit unit, ScheduledExecutorService executor, Single<T> fallback)
Switches to a fallback single if the upstream doesn't signal an item, error or completion within the specified time.Method parameters in io.helidon.common.reactive with type arguments of type Single Modifier and Type Method Description default <U> Single<U>
Single. compose(Function<? super Single<T>,? extends Single<? extends U>> composer)
Apply the givencomposer
function to the currentSingle
instance and return theSingle
returned by this function.default <U> Single<U>
Single. compose(Function<? super Single<T>,? extends Single<? extends U>> composer)
Apply the givencomposer
function to the currentSingle
instance and return theSingle
returned by this function.static <T> Single<T>
Single. defer(Supplier<? extends Single<? extends T>> supplier)
Call the given supplier function for each individual downstream Subscriber to return a Flow.Publisher to subscribe to.default <U> Single<U>
Single. flatMapSingle(Function<? super T,? extends Single<? extends U>> mapper)
Transforms item with supplied function and flatten resultingSingle
to downstream.default Single<T>
Single. onCompleteResumeWithSingle(Function<Optional<T>,? extends Single<? extends T>> onComplete)
Resume stream with supplied single if onComplete signal is intercepted.default Single<T>
Single. onErrorResumeWithSingle(Function<? super Throwable,? extends Single<? extends T>> onError)
Resume stream from supplied publisher if onError signal is intercepted.default <U> U
Single. to(Function<? super Single<T>,? extends U> converter)
Apply the givenconverter
function to the currentSingle
instance and return the value returned by this function. -
Uses of Single in io.helidon.dbclient
Methods in io.helidon.dbclient that return Single Modifier and Type Method Description default Single<Long>
DbExecute. delete(String statement, Object... parameters)
Create and execute delete statement using a statement passed as an argument.default Single<Long>
DbExecute. dml(String statement, Object... parameters)
Create and execute data modification statement using a statement passed as an argument.default Single<Optional<DbRow>>
DbExecute. get(String statement, Object... parameters)
Create and execute a database query using a statement passed as an argument.default Single<Long>
DbExecute. insert(String statement, Object... parameters)
Create and execute insert statement using a statement passed as an argument.default Single<Long>
DbExecute. namedDelete(String statementName, Object... parameters)
Create and execute delete statement using a statement defined in the configuration file.default Single<Long>
DbExecute. namedDml(String statementName, Object... parameters)
Create and execute a data modification statement using a statement defined in the configuration file.default Single<Optional<DbRow>>
DbExecute. namedGet(String statementName, Object... parameters)
Create and execute a database query using a statement defined in the configuration file.default Single<Long>
DbExecute. namedInsert(String statementName, Object... parameters)
Create and execute insert statement using a statement defined in the configuration file.default Single<Long>
DbExecute. namedUpdate(String statementName, Object... parameters)
Create and execute update statement using a statement defined in the configuration file.Single<DbClientServiceContext>
DbClientService. statement(DbClientServiceContext context)
Statement execution to be intercepted.<C> Single<C>
DbClient. unwrap(Class<C> cls)
Unwrap database client internals.<C> Single<C>
DbExecute. unwrap(Class<C> cls)
Unwrap database executor internals.default Single<Long>
DbExecute. update(String statement, Object... parameters)
Create and execute update statement using a statement passed as an argument. -
Uses of Single in io.helidon.dbclient.common
Methods in io.helidon.dbclient.common that return Single Modifier and Type Method Description protected abstract Single<DbClientServiceContext>
DbClientServiceBase. apply(DbClientServiceContext context)
This method is only invoked if the predicate for this service was passed.Single<DbClientServiceContext>
DbClientContext. invokeServices(DbClientServiceContext dbContext)
Invoke all configured client services and return a single that completes once all the client services complete.Single<DbClientServiceContext>
DbClientServiceBase. statement(DbClientServiceContext context)
Methods in io.helidon.dbclient.common with parameters of type Single Modifier and Type Method Description protected abstract R
AbstractStatement. doExecute(Single<DbClientServiceContext> dbContext, CompletableFuture<Void> statementFuture, CompletableFuture<Long> queryFuture)
Execute the statement against the database. -
Uses of Single in io.helidon.dbclient.mongodb
Methods in io.helidon.dbclient.mongodb that return Single Modifier and Type Method Description protected Single<Long>
MongoDbStatementDml. doExecute(Single<DbClientServiceContext> dbContext, CompletableFuture<Void> statementFuture, CompletableFuture<Long> queryFuture)
Single<Long>
MongoDbStatementDml. execute()
Single<Optional<DbRow>>
MongoDbStatementGet. execute()
<C> Single<C>
MongoDbClient. unwrap(Class<C> cls)
<C> Single<C>
MongoDbExecute. unwrap(Class<C> cls)
Methods in io.helidon.dbclient.mongodb with parameters of type Single Modifier and Type Method Description protected Single<Long>
MongoDbStatementDml. doExecute(Single<DbClientServiceContext> dbContext, CompletableFuture<Void> statementFuture, CompletableFuture<Long> queryFuture)
-
Uses of Single in io.helidon.dbclient.tracing
Methods in io.helidon.dbclient.tracing that return Single Modifier and Type Method Description protected Single<DbClientServiceContext>
DbClientTracing. apply(DbClientServiceContext serviceContext)
-
Uses of Single in io.helidon.faulttolerance
Methods in io.helidon.faulttolerance that return Single Modifier and Type Method Description <T> Single<T>
Async. invoke(Supplier<T> supplier)
Invoke a synchronous operation asynchronously.<T> Single<T>
FtHandler. invoke(Supplier<? extends CompletionStage<T>> supplier)
Invoke this fault tolerance handler on a supplier of aCompletionStage
, such as aSingle
.Single<T>
FtHandlerTyped. invoke(Supplier<? extends CompletionStage<T>> supplier)
Invoke this fault tolerance handler on a supplier of aCompletionStage
, such as aSingle
. -
Uses of Single in io.helidon.integrations.common.rest
Methods in io.helidon.integrations.common.rest that return Single Modifier and Type Method Description default <T extends ApiResponse>
Single<T>RestApi. delete(String path, ApiRequest<?> request, ApiResponse.Builder<?,T> responseBuilder)
Delete without a response entity.protected <T> Single<T>
RestApiBase. emptyResponse(String path, ApiRequest<?> request, Http.RequestMethod method, String requestId, WebClientResponse response, ResponseBuilder<?,T,?> responseBuilder)
Empty response, may be because of aHttp.Status.NOT_FOUND_404
, or some other status, such asHttp.Status.NOT_MODIFIED_304
.protected <T extends ApiResponse>
Single<T>RestApiBase. errorResponse(String path, ApiRequest<?> request, Http.RequestMethod method, String requestId, WebClientResponse response)
Create an error response.default <R,T extends ApiOptionalResponse<R>>
Single<T>RestApi. get(String path, ApiRequest<?> request, ApiOptionalResponse.BuilderBase<?,T,JsonObject,R> responseBuilder)
Get with an optional response.default <R,T extends ApiOptionalResponse<R>>
Single<T>RestApi. getBytes(String path, ApiRequest<?> request, ApiOptionalResponse.BuilderBase<?,T,byte[],R> responseBuilder)
Get bytes with an optional response.default <R,T extends ApiOptionalResponse<R>>
Single<T>RestApi. getPublisher(String path, ApiRequest<?> request, ApiOptionalResponse.BuilderBase<?,T,Multi<DataChunk>,R> responseBuilder)
Get with a response consisting of a stream.protected <R,T extends ApiOptionalResponse<R>>
Single<T>RestApiBase. handleBytesResponse(String path, ApiRequest<?> request, Http.RequestMethod method, String requestId, WebClientResponse response, ApiOptionalResponse.BuilderBase<?,T,byte[],R> responseBuilder)
Handle bytes response for optional bytes entity.protected <T extends ApiEntityResponse>
Single<T>RestApiBase. handleJsonResponse(String path, ApiRequest<?> request, Http.RequestMethod method, String requestId, WebClientResponse response, ApiEntityResponse.Builder<?,T,JsonObject> responseBuilder)
Reads JsonObject from response entity and either calls thejsonOkResponse
orerrorResponse
depending on its success.protected <R,T extends ApiOptionalResponse<R>>
Single<T>RestApiBase. handleOptionalJsonResponse(String path, ApiRequest<?> request, Http.RequestMethod method, String requestId, WebClientResponse response, ApiOptionalResponse.BuilderBase<?,T,JsonObject,R> responseBuilder)
Handle response for optional JSON entity.protected <R,T extends ApiOptionalResponse<R>>
Single<T>RestApiBase. handlePublisherResponse(String path, ApiRequest<?> request, Http.RequestMethod method, String requestId, WebClientResponse response, ApiOptionalResponse.BuilderBase<?,T,Multi<DataChunk>,R> responseBuilder)
Handle response for optional publisher entity.protected <T extends ApiResponse>
Single<T>RestApiBase. handleResponse(String path, ApiRequest<?> request, Http.RequestMethod method, String requestId, WebClientResponse response, ApiResponse.Builder<?,T> responseBuilder)
Handle response for a request not expecting an entity.<T extends ApiResponse>
Single<T>RestApi. invoke(Http.RequestMethod method, String path, ApiRequest<?> request, ApiResponse.Builder<?,T> responseBuilder)
Invoke a request that is not expected to yield an entity.<T extends ApiResponse>
Single<T>RestApiBase. invoke(Http.RequestMethod method, String path, ApiRequest<?> request, ApiResponse.Builder<?,T> responseBuilder)
<T extends ApiResponse>
Single<T>RestApi. invokeBytesRequest(Http.RequestMethod method, String path, ApiRequest<?> request, Flow.Publisher<DataChunk> byteRequest, ApiResponse.Builder<?,T> responseBuilder)
The request media type should be provided in request, falls back toMediaType.APPLICATION_OCTET_STREAM
.<T extends ApiResponse>
Single<T>RestApiBase. invokeBytesRequest(Http.RequestMethod method, String path, ApiRequest<?> request, Flow.Publisher<DataChunk> byteRequest, ApiResponse.Builder<?,T> responseBuilder)
<R,T extends ApiOptionalResponse<R>>
Single<T>RestApi. invokeBytesResponse(Http.RequestMethod method, String path, ApiRequest<?> request, ApiOptionalResponse.BuilderBase<?,T,byte[],R> responseBuilder)
Invoke API call that is expected to return bytes.<R,T extends ApiOptionalResponse<R>>
Single<T>RestApiBase. invokeBytesResponse(Http.RequestMethod method, String path, ApiRequest<?> request, ApiOptionalResponse.BuilderBase<?,T,byte[],R> responseBuilder)
<R,T extends ApiOptionalResponse<R>>
Single<T>RestApi. invokeOptional(Http.RequestMethod method, String path, ApiRequest<?> request, ApiOptionalResponse.BuilderBase<?,T,JsonObject,R> responseBuilder)
Invoke a request that may yield an entity.<R,T extends ApiOptionalResponse<R>>
Single<T>RestApiBase. invokeOptional(Http.RequestMethod method, String path, ApiRequest<?> request, ApiOptionalResponse.BuilderBase<?,T,JsonObject,R> responseBuilder)
<R,T extends ApiOptionalResponse<R>>
Single<T>RestApi. invokePublisherResponse(Http.RequestMethod method, String path, ApiRequest<?> request, ApiOptionalResponse.BuilderBase<?,T,Multi<DataChunk>,R> responseBuilder)
Invoke API call that is expected to return bytes as a publisher.<R,T extends ApiOptionalResponse<R>>
Single<T>RestApiBase. invokePublisherResponse(Http.RequestMethod method, String path, ApiRequest<?> request, ApiOptionalResponse.BuilderBase<?,T,Multi<DataChunk>,R> responseBuilder)
<T extends ApiEntityResponse>
Single<T>RestApi. invokeWithResponse(Http.RequestMethod method, String path, ApiRequest<?> request, ApiEntityResponse.Builder<?,T,JsonObject> responseBuilder)
Invoke a request that is expected to yield an entity.<T extends ApiEntityResponse>
Single<T>RestApiBase. invokeWithResponse(Http.RequestMethod method, String path, ApiRequest<?> request, ApiEntityResponse.Builder<?,T,JsonObject> responseBuilder)
protected <T extends ApiResponse>
Single<T>RestApiBase. noEntityOkResponse(String path, ApiRequest<?> request, Http.RequestMethod method, String requestId, WebClientResponse response, ApiResponse.Builder<?,T> responseBuilder)
Create a response for no entity.default <T extends ApiResponse>
Single<T>RestApi. post(String path, ApiRequest<?> request, ApiResponse.Builder<?,T> responseBuilder)
Post without a response entity.default <T extends ApiResponse>
Single<T>RestApi. put(String path, ApiRequest<?> request, ApiResponse.Builder<?,T> responseBuilder)
Put without a response entity.protected Single<WebClientRequestBuilder>
RestApiBase. updateRequestBuilder(WebClientRequestBuilder requestBuilder, String path, ApiRequest<?> request, Http.RequestMethod method, String requestId)
Update request builder with no request payload.protected Single<WebClientRequestBuilder>
RestApiBase. updateRequestBuilder(WebClientRequestBuilder requestBuilder, String path, ApiRequest<?> request, Http.RequestMethod method, String requestId, JsonObject jsonObject)
Update request builder with no request payload.protected Single<WebClientRequestBuilder>
RestApiBase. updateRequestBuilderBytesPayload(WebClientRequestBuilder requestBuilder, String path, ApiRequest<?> request, Http.RequestMethod method, String requestId)
Update request builder with publisher request payload.protected Single<WebClientRequestBuilder>
RestApiBase. updateRequestBuilderCommon(WebClientRequestBuilder requestBuilder, String path, ApiRequest<?> request, Http.RequestMethod method, String requestId)
Update request builder used by all default implementation inRestApiBase
.Methods in io.helidon.integrations.common.rest that return types with arguments of type Single Modifier and Type Method Description protected Supplier<Single<WebClientResponse>>
RestApiBase. requestBytesPayload(String path, ApiRequest<?> request, Http.RequestMethod method, String requestId, WebClientRequestBuilder requestBuilder, Flow.Publisher<DataChunk> publisher)
Create a supplier for a response with publisher request.protected Supplier<Single<WebClientResponse>>
RestApiBase. requestJsonPayload(String path, ApiRequest<?> request, Http.RequestMethod method, String requestId, WebClientRequestBuilder requestBuilder, JsonObject jsonObject)
Create a supplier for a response with JSON request.protected Supplier<Single<WebClientResponse>>
RestApiBase. requestPayload(String path, ApiRequest<?> request, Http.RequestMethod method, String requestId, WebClientRequestBuilder requestBuilder)
Create a supplier for a response.protected Supplier<Single<WebClientResponse>>
RestApiBase. responseSupplier(Http.RequestMethod method, String path, ApiRequest<?> request, String requestId)
Create a response supplier from the request. -
Uses of Single in io.helidon.integrations.oci.atp
Methods in io.helidon.integrations.oci.atp that return Single Modifier and Type Method Description Single<ApiOptionalResponse<GenerateAutonomousDatabaseWallet.Response>>
OciAutonomousDbRx. generateWallet(GenerateAutonomousDatabaseWallet.Request request)
Deprecated, for removal: This API element is subject to removal in a future version.Gets the metadata and body of Wallet. -
Uses of Single in io.helidon.integrations.oci.connect
Methods in io.helidon.integrations.oci.connect that return Single Modifier and Type Method Description Single<OciSignatureData>
OciConfigInstancePrincipal. refresh()
Deprecated, for removal: This API element is subject to removal in a future version.default Single<OciSignatureData>
OciConfigProvider. refresh()
Deprecated, for removal: This API element is subject to removal in a future version.Refresh may be used for providers that can be reloaded.Single<OciSignatureData>
OciConfigResourcePrincipal. refresh()
Deprecated, for removal: This API element is subject to removal in a future version.protected Single<WebClientRequestBuilder>
OciRestApi. updateRequestBuilder(WebClientRequestBuilder requestBuilder, String path, ApiRequest<?> request, Http.RequestMethod method, String requestId)
Deprecated, for removal: This API element is subject to removal in a future version.protected Single<WebClientRequestBuilder>
OciRestApi. updateRequestBuilderBytesPayload(WebClientRequestBuilder requestBuilder, String path, ApiRequest<?> request, Http.RequestMethod method, String requestId)
Deprecated, for removal: This API element is subject to removal in a future version.protected Single<WebClientRequestBuilder>
OciRestApi. updateRequestBuilderCommon(WebClientRequestBuilder requestBuilder, String path, ApiRequest<?> request, Http.RequestMethod method, String requestId)
Deprecated, for removal: This API element is subject to removal in a future version.Methods in io.helidon.integrations.oci.connect that return types with arguments of type Single Modifier and Type Method Description protected Supplier<Single<WebClientResponse>>
OciRestApi. requestBytesPayload(String path, ApiRequest<?> request, Http.RequestMethod method, String requestId, WebClientRequestBuilder requestBuilder, Flow.Publisher<DataChunk> publisher)
Deprecated, for removal: This API element is subject to removal in a future version.protected Supplier<Single<WebClientResponse>>
OciRestApi. requestJsonPayload(String path, ApiRequest<?> request, Http.RequestMethod method, String requestId, WebClientRequestBuilder requestBuilder, JsonObject jsonObject)
Deprecated, for removal: This API element is subject to removal in a future version.protected Supplier<Single<WebClientResponse>>
OciRestApi. responseSupplier(Http.RequestMethod method, String path, ApiRequest<?> request, String requestId)
Deprecated, for removal: This API element is subject to removal in a future version. -
Uses of Single in io.helidon.integrations.oci.objectstorage
Methods in io.helidon.integrations.oci.objectstorage that return Single Modifier and Type Method Description Single<DeleteObject.Response>
OciObjectStorageRx. deleteObject(DeleteObject.Request request)
Deprecated, for removal: This API element is subject to removal in a future version.Deletes an object.Single<ApiOptionalResponse<GetBucket.Response>>
OciObjectStorageRx. getBucket(GetBucket.Request request)
Deprecated, for removal: This API element is subject to removal in a future version.Gets the metadata of a bucket.Single<ApiOptionalResponse<GetObjectRx.Response>>
OciObjectStorageRx. getObject(GetObject.Request request)
Deprecated, for removal: This API element is subject to removal in a future version.Gets the metadata and body of an object.Single<PutObject.Response>
OciObjectStorageRx. putObject(PutObject.Request request, Flow.Publisher<DataChunk> publisher)
Deprecated, for removal: This API element is subject to removal in a future version.Creates a new object or overwrites an existing object with the same name.Single<RenameObject.Response>
OciObjectStorageRx. renameObject(RenameObject.Request request)
Deprecated, for removal: This API element is subject to removal in a future version.Rename an object in the given Object Storage namespace. -
Uses of Single in io.helidon.integrations.oci.telemetry
Methods in io.helidon.integrations.oci.telemetry that return Single Modifier and Type Method Description Single<PostMetricData.Response>
OciMetricsRx. postMetricData(PostMetricData.Request request)
Deprecated, for removal: This API element is subject to removal in a future version.Publishes raw metric data points to the Monitoring service. -
Uses of Single in io.helidon.integrations.oci.vault
Methods in io.helidon.integrations.oci.vault that return Single Modifier and Type Method Description Single<CreateSecret.Response>
OciVaultRx. createSecret(CreateSecret.Request request)
Deprecated, for removal: This API element is subject to removal in a future version.Create a new secret.Single<Decrypt.Response>
OciVaultRx. decrypt(Decrypt.Request request)
Deprecated, for removal: This API element is subject to removal in a future version.Decrypt data.Single<DeleteSecret.Response>
OciVaultRx. deleteSecret(DeleteSecret.Request request)
Deprecated, for removal: This API element is subject to removal in a future version.Schedules a secret deletion.Single<Encrypt.Response>
OciVaultRx. encrypt(Encrypt.Request request)
Deprecated, for removal: This API element is subject to removal in a future version.Encrypt data.Single<ApiOptionalResponse<GetKey.Response>>
OciVaultRx. getKey(GetKey.Request request)
Deprecated, for removal: This API element is subject to removal in a future version.Get key metadata.Single<ApiOptionalResponse<Secret>>
OciVaultRx. getSecret(GetSecret.Request request)
Deprecated, for removal: This API element is subject to removal in a future version.Gets information about the specified secret.Single<ApiOptionalResponse<GetSecretBundle.Response>>
OciVaultRx. getSecretBundle(GetSecretBundle.Request request)
Deprecated, for removal: This API element is subject to removal in a future version.Gets information about the specified secret.Single<ApiOptionalResponse<GetVault.Response>>
OciVaultRx. getVault(GetVault.Request request)
Deprecated, for removal: This API element is subject to removal in a future version.Get Vault metadata.Single<Sign.Response>
OciVaultRx. sign(Sign.Request request)
Deprecated, for removal: This API element is subject to removal in a future version.Sign a message.Single<Verify.Response>
OciVaultRx. verify(Verify.Request request)
Deprecated, for removal: This API element is subject to removal in a future version.Verify a message signature.Methods in io.helidon.integrations.oci.vault that return types with arguments of type Single Modifier and Type Method Description Supplier<Single<Optional<String>>>
OciVaultSecurityProvider. secret(Config config)
Supplier<Single<Optional<String>>>
OciVaultSecurityProvider. secret(OciVaultSecurityProvider.OciVaultSecretConfig providerConfig)
-
Uses of Single in io.helidon.integrations.vault
Methods in io.helidon.integrations.vault that return Single Modifier and Type Method Description default Single<List<String>>
SecretsRx. list()
List available secrets.Single<VaultOptionalResponse<ListSecrets.Response>>
SecretsRx. list(ListSecrets.Request request)
List available secrets.default Single<List<String>>
SecretsRx. list(String path)
List available secrets on a path. -
Uses of Single in io.helidon.integrations.vault.auths.approle
Methods in io.helidon.integrations.vault.auths.approle that return Single Modifier and Type Method Description Single<CreateAppRole.Response>
AppRoleAuthRx. createAppRole(CreateAppRole.Request appRoleRequest)
Creates a new AppRole or updates an existing AppRole.Single<DeleteAppRole.Response>
AppRoleAuthRx. deleteAppRole(DeleteAppRole.Request request)
Deletes an existing AppRole from the method with full control of request.Single<DestroySecretId.Response>
AppRoleAuthRx. destroySecretId(DestroySecretId.Request request)
Destroy an AppRole secret ID.Single<GenerateSecretId.Response>
AppRoleAuthRx. generateSecretId(GenerateSecretId.Request request)
Generates and issues a new SecretID on an existing AppRole.Single<Login.Response>
AppRoleAuthRx. login(Login.Request request)
Issues a Vault token based on the presented credentials.Single<VaultOptionalResponse<ReadRoleId.Response>>
AppRoleAuthRx. readRoleId(ReadRoleId.Request request)
Reads the RoleID of an existing AppRole with full control of request and response.default Single<Optional<String>>
AppRoleAuthRx. readRoleId(String appRole)
Reads the RoleID of an existing AppRole. -
Uses of Single in io.helidon.integrations.vault.auths.common
Methods in io.helidon.integrations.vault.auths.common that return Single Modifier and Type Method Description protected <T> Single<T>
VaultRestApi. emptyResponse(String path, ApiRequest<?> request, Http.RequestMethod method, String requestId, WebClientResponse response, ResponseBuilder<?,T,?> responseBuilder)
-
Uses of Single in io.helidon.integrations.vault.auths.k8s
Methods in io.helidon.integrations.vault.auths.k8s that return Single Modifier and Type Method Description Single<ConfigureK8s.Response>
K8sAuthRx. configure(ConfigureK8s.Request request)
Configure this authentication method.Single<CreateRole.Response>
K8sAuthRx. createRole(CreateRole.Request request)
Registers a role in the auth method.Single<DeleteRole.Response>
K8sAuthRx. deleteRole(DeleteRole.Request request)
Deletes the previously registered role.Single<Login.Response>
K8sAuthRx. login(Login.Request request)
Fetch a token. -
Uses of Single in io.helidon.integrations.vault.auths.token
Methods in io.helidon.integrations.vault.auths.token that return Single Modifier and Type Method Description default Single<CreateToken.Response>
TokenAuthRx. createOrphan()
Create a new orphan token with default configuration.default Single<CreateToken.Response>
TokenAuthRx. createToken()
Create a new child token with default configuration.Single<CreateToken.Response>
TokenAuthRx. createToken(CreateToken.Request request)
Create a new token with customized configuration.Single<CreateTokenRole.Response>
TokenAuthRx. createTokenRole(CreateTokenRole.Request request)
Creates (or replaces) the named role.Single<DeleteTokenRole.Response>
TokenAuthRx. deleteTokenRole(DeleteTokenRole.Request request)
Delete a named token role.Single<RenewToken.Response>
TokenAuthRx. renew(RenewToken.Request request)
Renews a lease associated with a token.Single<RevokeToken.Response>
TokenAuthRx. revoke(RevokeToken.Request request)
Revokes a token and all child tokens.Single<RevokeAndOrphanToken.Response>
TokenAuthRx. revokeAndOrphan(RevokeAndOrphanToken.Request request)
Revokes a token and orphans all child tokens. -
Uses of Single in io.helidon.integrations.vault.secrets.cubbyhole
Methods in io.helidon.integrations.vault.secrets.cubbyhole that return Single Modifier and Type Method Description Single<CreateCubbyhole.Response>
CubbyholeSecretsRx. create(CreateCubbyhole.Request request)
Create a new secret on the defined path.default Single<CreateCubbyhole.Response>
CubbyholeSecretsRx. create(String path, Map<String,String> values)
Create a Cubbyhole secret.Single<DeleteCubbyhole.Response>
CubbyholeSecretsRx. delete(DeleteCubbyhole.Request request)
Delete the secret.default Single<DeleteCubbyhole.Response>
CubbyholeSecretsRx. delete(String path)
Delete a Cubbyhole secret.Single<VaultOptionalResponse<GetCubbyhole.Response>>
CubbyholeSecretsRx. get(GetCubbyhole.Request request)
Get a secret.default Single<Optional<Secret>>
CubbyholeSecretsRx. get(String path)
Get a Cubbyhole secret.Single<UpdateCubbyhole.Response>
CubbyholeSecretsRx. update(UpdateCubbyhole.Request request)
Update a secret on the defined path.Methods in io.helidon.integrations.vault.secrets.cubbyhole that return types with arguments of type Single Modifier and Type Method Description Supplier<Single<Optional<String>>>
CubbyholeSecurityProvider. secret(Config config)
Supplier<Single<Optional<String>>>
CubbyholeSecurityProvider. secret(CubbyholeSecurityProvider.CubbyholeSecretConfig providerConfig)
-
Uses of Single in io.helidon.integrations.vault.secrets.database
Methods in io.helidon.integrations.vault.secrets.database that return Single Modifier and Type Method Description Single<DbConfigure.Response>
DbSecretsRx. configure(DbConfigure.Request<?> dbRequest)
Configure a database.Single<DbCreateRole.Response>
DbSecretsRx. createRole(DbCreateRole.Request request)
Create or update a role definition.Single<DbDelete.Response>
DbSecretsRx. delete(DbDelete.Request request)
Delete a database configuration.default Single<DbDelete.Response>
DbSecretsRx. delete(String name)
Delete a database configuration.Single<DbDeleteRole.Response>
DbSecretsRx. deleteRole(DbDeleteRole.Request request)
Delete a database role.default Single<DbDeleteRole.Response>
DbSecretsRx. deleteRole(String name)
Delete a database role.Single<VaultOptionalResponse<DbGet.Response>>
DbSecretsRx. get(DbGet.Request request)
Get credentials from the/creds
endpoint.default Single<Optional<DbCredentials>>
DbSecretsRx. get(String name)
Get credentials from the/creds
endpoint.Single<VaultOptionalResponse<ListSecrets.Response>>
DbSecretsRx. list(ListSecrets.Request request)
List database connections. -
Uses of Single in io.helidon.integrations.vault.secrets.kv1
Methods in io.helidon.integrations.vault.secrets.kv1 that return Single Modifier and Type Method Description Single<CreateKv1.Response>
Kv1SecretsRx. create(CreateKv1.Request request)
Create a new secret on the defined path.default Single<CreateKv1.Response>
Kv1SecretsRx. create(String path, Map<String,String> newSecretValues)
Create a new secret on the defined path.Single<DeleteKv1.Response>
Kv1SecretsRx. delete(DeleteKv1.Request request)
Delete the secret.default Single<DeleteKv1.Response>
Kv1SecretsRx. delete(String path)
Delete the secret.Single<VaultOptionalResponse<GetKv1.Response>>
Kv1SecretsRx. get(GetKv1.Request request)
Get a secret.default Single<Optional<Secret>>
Kv1SecretsRx. get(String path)
Get a secret.Single<UpdateKv1.Response>
Kv1SecretsRx. update(UpdateKv1.Request request)
Update a secret on the defined path.default Single<UpdateKv1.Response>
Kv1SecretsRx. update(String path, Map<String,String> newValues)
Update a secret on the defined path.Methods in io.helidon.integrations.vault.secrets.kv1 that return types with arguments of type Single Modifier and Type Method Description Supplier<Single<Optional<String>>>
Kv1SecurityProvider. secret(Config config)
Supplier<Single<Optional<String>>>
Kv1SecurityProvider. secret(Kv1SecurityProvider.Kv1SecretConfig providerConfig)
-
Uses of Single in io.helidon.integrations.vault.secrets.kv2
Methods in io.helidon.integrations.vault.secrets.kv2 that return Single Modifier and Type Method Description Single<CreateKv2.Response>
Kv2SecretsRx. create(CreateKv2.Request request)
Create a new secret.default Single<CreateKv2.Response>
Kv2SecretsRx. create(String path, Map<String,String> newSecretValues)
Create a new secret on the defined path.Single<DeleteKv2.Response>
Kv2SecretsRx. delete(DeleteKv2.Request request)
Delete a secret version.default Single<DeleteKv2.Response>
Kv2SecretsRx. delete(String path, int... versions)
Delete specific versions of a secret.Single<DeleteAllKv2.Response>
Kv2SecretsRx. deleteAll(DeleteAllKv2.Request request)
Delete the secret and all its versions permanently.default Single<DeleteAllKv2.Response>
Kv2SecretsRx. deleteAll(String path)
Delete the secret and all its versions permanently.Single<DestroyKv2.Response>
Kv2SecretsRx. destroy(DestroyKv2.Request request)
Permanently remove specific version(s) of a secret.default Single<DestroyKv2.Response>
Kv2SecretsRx. destroy(String path, int... versions)
Permanently remove specific versions of a secret.Single<VaultOptionalResponse<GetKv2.Response>>
Kv2SecretsRx. get(GetKv2.Request request)
Get a version of a secret.default Single<Optional<Kv2Secret>>
Kv2SecretsRx. get(String path)
Get the latest version of a secret.default Single<Optional<Kv2Secret>>
Kv2SecretsRx. get(String path, int version)
Get a version of a secret.Single<UndeleteKv2.Response>
Kv2SecretsRx. undelete(UndeleteKv2.Request request)
Undelete a secret version.default Single<UndeleteKv2.Response>
Kv2SecretsRx. undelete(String path, int... versions)
Undelete deleted versions of a secret.Single<UpdateKv2.Response>
Kv2SecretsRx. update(UpdateKv2.Request request)
Update a secret on the defined path.default Single<Integer>
Kv2SecretsRx. update(String path, Map<String,String> newValues)
Update a secret on the defined path.default Single<Integer>
Kv2SecretsRx. update(String path, Map<String,String> newValues, int expectedVersion)
Update a secret on the defined path.Methods in io.helidon.integrations.vault.secrets.kv2 that return types with arguments of type Single Modifier and Type Method Description Supplier<Single<Optional<String>>>
Kv2SecurityProvider. secret(Config config)
Supplier<Single<Optional<String>>>
Kv2SecurityProvider. secret(Kv2SecurityProvider.Kv2SecretConfig providerConfig)
-
Uses of Single in io.helidon.integrations.vault.secrets.pki
Methods in io.helidon.integrations.vault.secrets.pki that return Single Modifier and Type Method Description default Single<X509Certificate>
PkiSecretsRx. caCertificate()
Certification authority certificate.Single<CaCertificateGet.Response>
PkiSecretsRx. caCertificate(CaCertificateGet.Request request)
Certification authority certificate.default Single<byte[]>
PkiSecretsRx. caCertificate(PkiFormat format)
Certification authority certificate in raw bytes.Single<VaultOptionalResponse<CertificateGet.Response>>
PkiSecretsRx. certificate(CertificateGet.Request request)
Get a certificate.default Single<Optional<X509Certificate>>
PkiSecretsRx. certificate(String serialNumber)
Certificate with the defined serial id.default Single<Optional<byte[]>>
PkiSecretsRx. certificate(String serialNumber, PkiFormat format)
Certificate in raw bytes, currently onlyPkiFormat.PEM
is supported.Single<PkiRole.Response>
PkiSecretsRx. createOrUpdateRole(PkiRole.Request request)
This endpoint creates or updates the role definition.default Single<X509CRL>
PkiSecretsRx. crl()
Certificate revocation list.Single<CrlGet.Response>
PkiSecretsRx. crl(CrlGet.Request request)
Certificate revocation list.default Single<byte[]>
PkiSecretsRx. crl(PkiFormat format)
Certificate revocation list in raw bytes.Single<GenerateSelfSignedRoot.Response>
PkiSecretsRx. generateSelfSignedRoot(GenerateSelfSignedRoot.Request request)
Generate a self signed root certificate.default Single<GenerateSelfSignedRoot.Response>
PkiSecretsRx. generateSelfSignedRoot(String commonName)
Generate a self signed root certificate.Single<IssueCertificate.Response>
PkiSecretsRx. issueCertificate(IssueCertificate.Request request)
Issue a new certificate returning raw data.Single<VaultOptionalResponse<ListSecrets.Response>>
PkiSecretsRx. list(ListSecrets.Request request)
List certificate serial numbers.Single<RevokeCertificate.Response>
PkiSecretsRx. revokeCertificate(RevokeCertificate.Request request)
Revoke a certificate.default Single<Instant>
PkiSecretsRx. revokeCertificate(String serialNumber)
Revoke a certificate by its serial number.Single<SignCsr.Response>
PkiSecretsRx. signCertificateRequest(SignCsr.Request request)
This endpoint signs a new certificate based upon the provided CSR and the supplied parameters, subject to the restrictions contained in the role named in the endpoint. -
Uses of Single in io.helidon.integrations.vault.secrets.transit
Methods in io.helidon.integrations.vault.secrets.transit that return Single Modifier and Type Method Description Single<CreateKey.Response>
TransitSecretsRx. createKey(CreateKey.Request request)
Creates a new named encryption key of the specified type.Single<Decrypt.Response>
TransitSecretsRx. decrypt(Decrypt.Request request)
Decrypts the provided ciphertext using the named key.Single<DecryptBatch.Response>
TransitSecretsRx. decrypt(DecryptBatch.Request request)
Decrypts the provided batch of ciphertext strings using the named key.Single<DeleteKey.Response>
TransitSecretsRx. deleteKey(DeleteKey.Request request)
Delete a named ecryption key.Single<Encrypt.Response>
TransitSecretsRx. encrypt(Encrypt.Request request)
Encrypts the provided plaintext using the named key.Single<EncryptBatch.Response>
TransitSecretsRx. encrypt(EncryptBatch.Request request)
Encrypts the provided batch of plaintext strings using the named key.Single<Hmac.Response>
TransitSecretsRx. hmac(Hmac.Request request)
Hmac of a message.Single<VaultOptionalResponse<ListSecrets.Response>>
TransitSecretsRx. list(ListSecrets.Request request)
List available keys.Single<Sign.Response>
TransitSecretsRx. sign(Sign.Request request)
Sign a message.Single<UpdateKeyConfig.Response>
TransitSecretsRx. updateKeyConfig(UpdateKeyConfig.Request request)
Tune configuration of a key.Single<Verify.Response>
TransitSecretsRx. verify(Verify.Request request)
Verify a message signature. -
Uses of Single in io.helidon.integrations.vault.sys
Methods in io.helidon.integrations.vault.sys that return Single Modifier and Type Method Description Single<CreatePolicy.Response>
SysRx. createPolicy(CreatePolicy.Request request)
Create a policy.default Single<CreatePolicy.Response>
SysRx. createPolicy(String name, String policy)
Create a policy.Single<DeletePolicy.Response>
SysRx. deletePolicy(DeletePolicy.Request request)
Delete a policy.default Single<DeletePolicy.Response>
SysRx. deletePolicy(String name)
Delete a policy.Single<DisableAuth.Response>
SysRx. disableAuth(DisableAuth.Request request)
Disable an authentication method.default Single<DisableAuth.Response>
SysRx. disableAuth(String path)
Disable an authentication method.default Single<DisableEngine.Response>
SysRx. disableEngine(Engine<?> engine)
Disable (unmount) a secret engine from default path.Single<DisableEngine.Response>
SysRx. disableEngine(DisableEngine.Request request)
Disable (unmount) a secrets engine.default Single<DisableEngine.Response>
SysRx. disableEngine(String path)
Disable (unmount) a secrets engine from specific path.default Single<EnableAuth.Response>
SysRx. enableAuth(AuthMethod<?> authMethod)
Enable an authentication method on default path.Single<EnableAuth.Response>
SysRx. enableAuth(EnableAuth.Request request)
Enable an authentication method on custom path or with additional configuration.default Single<EnableEngine.Response>
SysRx. enableEngine(Engine<?> engine)
Enable (mount) a secret engine on a default path.Single<EnableEngine.Response>
SysRx. enableEngine(EnableEngine.Request request)
Enable (mount) a secret engine with custom configuration. -
Uses of Single in io.helidon.lra.coordinator.client
Methods in io.helidon.lra.coordinator.client that return Single Modifier and Type Method Description default Single<Void>
CoordinatorClient. cancel(URI lraId)
Deprecated, for removal: This API element is subject to removal in a future version.Single<Void>
CoordinatorClient. cancel(URI lraId, PropagatedHeaders headers)
Cancel LRA if its active.default Single<Void>
CoordinatorClient. close(URI lraId)
Deprecated, for removal: This API element is subject to removal in a future version.Single<Void>
CoordinatorClient. close(URI lraId, PropagatedHeaders headers)
Close LRA if its active.default Single<Optional<URI>>
CoordinatorClient. join(URI lraId, long timeLimit, Participant participant)
Deprecated, for removal: This API element is subject to removal in a future version.Single<Optional<URI>>
CoordinatorClient. join(URI lraId, PropagatedHeaders headers, long timeLimit, Participant participant)
Join existing LRA with participant.default Single<Void>
CoordinatorClient. leave(URI lraId, Participant participant)
Deprecated, for removal: This API element is subject to removal in a future version.Single<Void>
CoordinatorClient. leave(URI lraId, PropagatedHeaders headers, Participant participant)
Leave LRA.default Single<URI>
CoordinatorClient. start(String clientID, long timeout)
Deprecated, for removal: This API element is subject to removal in a future version.Single<URI>
CoordinatorClient. start(String clientID, PropagatedHeaders headers, long timeout)
Ask coordinator to start new LRA and return its id.default Single<URI>
CoordinatorClient. start(URI parentLRA, String clientID, long timeout)
Deprecated, for removal: This API element is subject to removal in a future version.Single<URI>
CoordinatorClient. start(URI parentLRA, String clientID, PropagatedHeaders headers, long timeout)
Ask coordinator to start new LRA and return its id.default Single<LRAStatus>
CoordinatorClient. status(URI lraId)
Deprecated, for removal: This API element is subject to removal in a future version.Single<LRAStatus>
CoordinatorClient. status(URI lraId, PropagatedHeaders headers)
Return status of specified LRA. -
Uses of Single in io.helidon.lra.coordinator.client.narayana
Methods in io.helidon.lra.coordinator.client.narayana that return Single Modifier and Type Method Description Single<Void>
NarayanaClient. cancel(URI lraId, PropagatedHeaders headers)
Single<Void>
NarayanaClient. close(URI lraId, PropagatedHeaders headers)
Single<Optional<URI>>
NarayanaClient. join(URI lraId, PropagatedHeaders headers, long timeLimit, Participant p)
Single<Void>
NarayanaClient. leave(URI lraId, PropagatedHeaders headers, Participant p)
Single<URI>
NarayanaClient. start(String clientID, PropagatedHeaders headers, long timeout)
Single<URI>
NarayanaClient. start(URI parentLRAUri, String clientID, PropagatedHeaders headers, long timeout)
Single<LRAStatus>
NarayanaClient. status(URI lraId, PropagatedHeaders headers)
-
Uses of Single in io.helidon.media.common
Methods in io.helidon.media.common that return Single Modifier and Type Method Description <T> Single<T>
MessageBodyReadableContent. as(GenericType<T> type)
Consumes and converts the content payload into a completion stage of the requested type.<T> Single<T>
MessageBodyReadableContent. as(Class<T> type)
<U extends T>
Single<U>MessageBodyReader. read(Flow.Publisher<DataChunk> publisher, GenericType<U> type, MessageBodyReaderContext context)
Convert a HTTP payload into a Single publisher of the given type.static Single<byte[]>
ContentReaders. readBytes(Flow.Publisher<DataChunk> chunks)
Collect theDataChunk
of the given publisher into a single byte array.static Single<String>
ContentReaders. readString(Flow.Publisher<DataChunk> chunks, Charset charset)
static Single<String>
ContentReaders. readURLEncodedString(Flow.Publisher<DataChunk> chunks, Charset charset)
default Single<T>
MessageBodyReader. unmarshall(MessageBodyReadableContent content, GenericType<T> type)
Unmarshall the given content using this reader.default Single<T>
MessageBodyReader. unmarshall(MessageBodyReadableContent content, Class<T> type)
Unmarshall the given content using this reader.<T> Single<T>
MessageBodyReaderContext. unmarshall(Flow.Publisher<DataChunk> payload, GenericType<T> type)
Convert a given HTTP payload into a publisher by selecting a reader that accepts the specified type and current context.<T> Single<T>
MessageBodyReaderContext. unmarshall(Flow.Publisher<DataChunk> payload, MessageBodyReader<T> reader, GenericType<T> type)
Convert a given HTTP payload into a publisher by selecting a reader with the specified class.static Single<DataChunk>
ContentWriters. writeBytes(byte[] bytes, boolean copy)
static Single<DataChunk>
ContentWriters. writeCharBuffer(CharBuffer buffer, Charset charset)
static Single<DataChunk>
ContentWriters. writeCharSequence(CharSequence cs, Charset charset)
static Single<DataChunk>
ContentWriters. writeStackTrace(Throwable throwable, Charset charset)
Methods in io.helidon.media.common with parameters of type Single Modifier and Type Method Description <T> Flow.Publisher<DataChunk>
MessageBodyWriterContext. marshall(Single<T> content, GenericType<T> type)
Convert a given input publisher into HTTP payload by selecting a writer that accepts the specified type and current context.<T> Flow.Publisher<DataChunk>
MessageBodyWriterContext. marshall(Single<T> content, MessageBodyWriter<T> writer, GenericType<T> type)
Convert a given input publisher into HTTP payload by selecting a writer with the specified class.Flow.Publisher<DataChunk>
MessageBodyWriter. write(Single<? extends T> single, GenericType<? extends T> type, MessageBodyWriterContext context)
Generate HTTP payload from the objects of the given type. -
Uses of Single in io.helidon.media.multipart
Methods in io.helidon.media.multipart that return Single Modifier and Type Method Description <U extends MultiPart>
Single<U>MultiPartBodyReader. read(Flow.Publisher<DataChunk> publisher, GenericType<U> type, MessageBodyReaderContext context)
Deprecated, for removal: This API element is subject to removal in a future version.Methods in io.helidon.media.multipart with parameters of type Single Modifier and Type Method Description Flow.Publisher<DataChunk>
MultiPartBodyWriter. write(Single<? extends WriteableMultiPart> content, GenericType<? extends WriteableMultiPart> type, MessageBodyWriterContext context)
-
Uses of Single in io.helidon.security
Methods in io.helidon.security that return Single Modifier and Type Method Description Single<byte[]>
Security. decrypt(String configurationName, String cipherText)
Decrypt cipher text.Single<String>
Security. digest(String configurationName, byte[] bytesToDigest)
Create a digest for the provided raw bytes.Single<String>
Security. digest(String configurationName, byte[] bytesToDigest, boolean preHashed)
Create a digest for the provided bytes.Single<String>
Security. encrypt(String configurationName, byte[] bytesToEncrypt)
Encrypt bytes.Single<Optional<String>>
Security. secret(String configurationName)
Get a secret.Single<String>
Security. secret(String configurationName, String defaultValue)
Get a secret.Single<Boolean>
Security. verifyDigest(String configurationName, byte[] bytesToDigest, String digest)
Verify a digest.Single<Boolean>
Security. verifyDigest(String configurationName, byte[] bytesToDigest, String digest, boolean preHashed)
Verify a digest. -
Uses of Single in io.helidon.security.providers.config.vault
Methods in io.helidon.security.providers.config.vault that return types with arguments of type Single Modifier and Type Method Description Supplier<Single<Optional<String>>>
ConfigVaultProvider. secret(Config config)
Supplier<Single<Optional<String>>>
ConfigVaultProvider. secret(ConfigVaultProvider.SecretConfig providerConfig)
Method parameters in io.helidon.security.providers.config.vault with type arguments of type Single Modifier and Type Method Description static ConfigVaultProvider.SecretConfig
ConfigVaultProvider.SecretConfig. createSingleSupplier(Supplier<Single<Optional<String>>> valueSupplier)
Create a new secret configuration with a supplier of a future (Single
), such as when retrieving the secret from a remote service. -
Uses of Single in io.helidon.security.providers.idcs.mapper
Methods in io.helidon.security.providers.idcs.mapper that return Single Modifier and Type Method Description protected Single<List<? extends Grant>>
IdcsMtRoleMapperRxProvider. addAdditionalGrants(String idcsTenantId, String idcsAppName, Subject subject, List<Grant> idcsGrants)
Extension point to add additional grants to the subject being created.protected Single<List<? extends Grant>>
IdcsRoleMapperRxProvider. addAdditionalGrants(Subject subject, List<Grant> idcsGrants)
Extension point to add additional grants that are not retrieved from IDCS.protected Single<List<? extends Grant>>
IdcsMtRoleMapperRxProvider. computeGrants(String idcsTenantId, String idcsAppName, Subject subject)
Compute grants for the provided MT information.protected Single<List<? extends Grant>>
IdcsRoleMapperRxProvider. computeGrants(Subject subject)
Compute grants for the provided subject.protected Single<Subject>
IdcsMtRoleMapperRxProvider. enhance(ProviderRequest request, AuthenticationResponse previousResponse, Subject subject)
Enhance the subject with appropriate roles from IDCS.protected Single<Subject>
IdcsRoleMapperRxProvider. enhance(ProviderRequest request, AuthenticationResponse previousResponse, Subject subject)
protected abstract Single<Subject>
IdcsRoleMapperRxProviderBase. enhance(ProviderRequest request, AuthenticationResponse previousResponse, Subject subject)
Enhance subject with IDCS roles, reactive.protected Single<Optional<String>>
IdcsMtRoleMapperRxProvider. getAppToken(String idcsTenantId, RoleMapTracing tracing)
Gets token from cache or from server.protected Single<List<? extends Grant>>
IdcsMtRoleMapperRxProvider. getGrantsFromServer(String idcsTenantId, String idcsAppName, Subject subject)
Get grants from IDCS server.protected Single<List<? extends Grant>>
IdcsRoleMapperRxProvider. getGrantsFromServer(Subject subject)
Retrieves grants from IDCS server.protected Single<Optional<String>>
IdcsRoleMapperRxProviderBase.AppTokenRx. getToken(RoleMapTracing tracing)
Single<AuthenticationResponse>
IdcsRoleMapperRxProviderBase. map(ProviderRequest authenticatedRequest, AuthenticationResponse previousResponse)
protected Single<List<? extends Grant>>
IdcsRoleMapperRxProviderBase. processRoleRequest(WebClientRequestBuilder request, Object entity, String subjectName)
-
Uses of Single in io.helidon.security.providers.oidc.common
Methods in io.helidon.security.providers.oidc.common that return Single Modifier and Type Method Description Single<SetCookie.Builder>
OidcCookieHandler. createCookie(String value)
SetCookie
builder to set a new cookie, returns a future, as the value may need to be encrypted using a remote service.Single<String>
OidcCookieHandler. decrypt(String cipherText)
Decrypt a cipher text into clear text (if encryption is enabled).static <T> Single<T>
OidcConfig. postJsonResponse(WebClientRequestBuilder requestBuilder, Object toSubmit, Function<JsonObject,T> jsonProcessor, BiFunction<Http.ResponseStatus,String,Optional<T>> errorEntityProcessor, BiFunction<Throwable,String,Optional<T>> errorProcessor)
Processing ofWebClient
submit using a POST method.Methods in io.helidon.security.providers.oidc.common that return types with arguments of type Single Modifier and Type Method Description Optional<Single<String>>
OidcCookieHandler. findCookie(Map<String,List<String>> headers)
Locate cookie in a map of headers and return its value. -
Uses of Single in io.helidon.security.spi
Methods in io.helidon.security.spi that return Single Modifier and Type Method Description Single<String>
DigestProvider.DigestFunction. apply(byte[] data, Boolean preHashed)
Create digest.Single<Boolean>
DigestProvider.VerifyFunction. apply(byte[] data, Boolean preHashed, String digest)
Verify digest.Single<byte[]>
EncryptionProvider.EncryptionSupport. decrypt(String encrypted)
Decrypt the bytes.Single<String>
DigestProvider.DigestSupport. digest(byte[] bytes, boolean preHashed)
Generates a signature or an HMAC.Single<String>
EncryptionProvider.EncryptionSupport. encrypt(byte[] bytes)
Encrypt the bytes.Single<Boolean>
DigestProvider.DigestSupport. verify(byte[] bytes, boolean preHashed, String digest)
Verifies a signature or an HMAC.Methods in io.helidon.security.spi that return types with arguments of type Single Modifier and Type Method Description Supplier<Single<Optional<String>>>
SecretsProvider. secret(Config config)
Create secret supplier from configuration.Supplier<Single<Optional<String>>>
SecretsProvider. secret(T providerConfig)
Create secret supplier from configuration object.Method parameters in io.helidon.security.spi with type arguments of type Single Modifier and Type Method Description static EncryptionProvider.EncryptionSupport
EncryptionProvider.EncryptionSupport. create(Function<byte[],Single<String>> encryptionFunction, Function<String,Single<byte[]>> decryptionFunction)
Create a new support based on encrypt and decrypt functions.Constructor parameters in io.helidon.security.spi with type arguments of type Single Constructor Description EncryptionSupport(Function<byte[],Single<String>> encryptionFunction, Function<String,Single<byte[]>> decryptionFunction)
Encryption support based on the two functions. -
Uses of Single in io.helidon.webclient
Methods in io.helidon.webclient that return Single Modifier and Type Method Description Single<Void>
WebClientResponse. close()
Asynchronous close of the response.Single<WebClientResponse>
WebClientRequestBuilder. request()
Performs prepared request without expecting to receive any specific type.<T> Single<T>
WebClientRequestBuilder. request(GenericType<T> responseType)
Performs prepared request and transforms response to requested type.<T> Single<T>
WebClientRequestBuilder. request(Class<T> responseType)
Performs prepared request and transforms response to requested type.Single<WebClientResponse>
WebClientRequestBuilder. submit()
Performs prepared request.Single<WebClientResponse>
WebClientRequestBuilder. submit(Object requestEntity)
Performs prepared request and submitting request entity.<T> Single<T>
WebClientRequestBuilder. submit(Object requestEntity, Class<T> responseType)
Performs prepared request and submitting request entity.Single<WebClientResponse>
WebClientRequestBuilder. submit(Flow.Publisher<DataChunk> requestEntity)
Performs prepared request and submitting request entity usingFlow.Publisher
.<T> Single<T>
WebClientRequestBuilder. submit(Flow.Publisher<DataChunk> requestEntity, Class<T> responseType)
Performs prepared request and submitting request entity usingFlow.Publisher
.Single<WebClientResponse>
WebClientRequestBuilder. submit(Function<MessageBodyWriterContext,Flow.Publisher<DataChunk>> function)
Performs prepared request and submitting request entity using a marshalling function.Single<WebClientServiceResponse>
WebClientServiceRequest. whenComplete()
Completes when the full processing of this request is done (e.g.Single<WebClientServiceResponse>
WebClientServiceRequest. whenResponseReceived()
Completes when the response headers has been received, but entity has not been processed yet.Single<WebClientServiceRequest>
WebClientServiceRequest. whenSent()
Completes when the request part of this request is done (e.g. -
Uses of Single in io.helidon.webclient.context.propagation
Methods in io.helidon.webclient.context.propagation that return Single Modifier and Type Method Description Single<WebClientServiceRequest>
WebClientContextPropagation. request(WebClientServiceRequest request)
-
Uses of Single in io.helidon.webclient.metrics
Methods in io.helidon.webclient.metrics that return Single Modifier and Type Method Description Single<WebClientServiceRequest>
WebClientMeter. request(WebClientServiceRequest request)
Single<WebClientServiceRequest>
WebClientMetrics. request(WebClientServiceRequest request)
Single<WebClientServiceResponse>
WebClientMetrics. response(WebClientRequestBuilder.ClientRequest request, WebClientServiceResponse response)
-
Uses of Single in io.helidon.webclient.security
Methods in io.helidon.webclient.security that return Single Modifier and Type Method Description Single<WebClientServiceRequest>
WebClientSecurity. request(WebClientServiceRequest request)
-
Uses of Single in io.helidon.webclient.spi
Methods in io.helidon.webclient.spi that return Single Modifier and Type Method Description Single<WebClientServiceRequest>
WebClientService. request(WebClientServiceRequest request)
Method which is called before send actual request.default Single<WebClientServiceResponse>
WebClientService. response(WebClientRequestBuilder.ClientRequest request, WebClientServiceResponse response)
Method which is called when the last byte of the response is processed. -
Uses of Single in io.helidon.webclient.tracing
Methods in io.helidon.webclient.tracing that return Single Modifier and Type Method Description Single<WebClientServiceRequest>
WebClientTracing. request(WebClientServiceRequest request)
-
Uses of Single in io.helidon.webserver
Methods in io.helidon.webserver that return Single Modifier and Type Method Description Single<Void>
BareRequest. closeConnection()
Request to close the connection and report success or failure asynchronously with returned single.Single<Void>
ServerRequest. closeConnection()
Request to close the connection and report success or failure asynchronously with returned single.Single<ResponseHeaders>
ResponseHeaders. send()
Send headers and status code to the client.Single<ServerResponse>
ServerResponse. send()
Sends an empty response.Single<ServerResponse>
ServerResponse. send(Flow.Publisher<DataChunk> content)
Send a message as is without any other marshalling, registered filters are applied.Single<ServerResponse>
ServerResponse. send(Flow.Publisher<DataChunk> content, boolean applyFilters)
Send a message as is without any other marshalling.<T> Single<ServerResponse>
ServerResponse. send(Flow.Publisher<T> content, Class<T> clazz)
Send a message with the given entity stream as content and close the response.Single<ServerResponse>
ServerResponse. send(Function<MessageBodyWriterContext,Flow.Publisher<DataChunk>> function)
Send a message using the given marshalling function.<T> Single<ServerResponse>
ServerResponse. send(T content)
Send a message and close the response.Single<WebServer>
WebServer. shutdown()
Attempt to gracefully shutdown server.Single<WebServer>
WebServer. start()
Starts the server.Single<BareResponse>
BareResponse. whenCompleted()
Returns aSingle
of this response.Single<BareResponse>
BareResponse. whenHeadersCompleted()
Returns aSingle
of headers part of this response.default Single<ResponseHeaders>
ResponseHeaders. whenSend()
Deprecated.since 2.0.0, please useResponseHeaders.whenSent()
Single<ResponseHeaders>
ResponseHeaders. whenSent()
Returns aSingle
which is completed when all headers are sent to the client.Single<ServerResponse>
ServerResponse. whenSent()
Completion stage is completed when response is completed.Single<WebServer>
WebServer. whenShutdown()
Completion stage is completed when server is shut down.
-