Uses of Interface
ratpack.func.Action
-
Packages that use Action Package Description ratpack.config Provides the ability to access configuration data from a variety of sources, such as YAML, JSON, properties files, system properties, and environment variables.ratpack.consul Support for integrating Ratpack applications with Hashicorp's Consul service discovery and distributed configuration engine.ratpack.core.handling The handling of application requests.ratpack.core.handling.direct Low level direct access to the underlying Netty internals.ratpack.core.http The HTTP protocol.ratpack.core.http.client The HTTP client.ratpack.core.impose ratpack.core.logging Utility classes for integration Ratpack with various logging frameworks.ratpack.core.path Types for managing the paths of requests inside the application.ratpack.core.render The renderer framework provides a pluggable mechanism for serializing objects to the response.ratpack.core.server Objects used to start a ratpack application.ratpack.core.service Services participate in the application start/stop lifecycle.ratpack.core.sse.client ratpack.core.websocket Support for Websockets.ratpack.dropwizard.metrics Integration with Dropwizard Metrics Library.ratpack.exec The execution management.ratpack.exec.registry Registries hold objects that can be retrieved via type, and are a key aspect of Ratpack applications.ratpack.exec.stream Support for reactive streams.ratpack.exec.util ratpack.exec.util.retry ratpack.func ratpack.groovy Support for writing Ratpack applications in the Groovy programming language.ratpack.groovy.handling Groovy specific extensions to classes in theratpack.core.handling
package.ratpack.groovy.server Groovy implementations of the Ratpack server building classes.ratpack.groovy.test.handling ratpack.guice Integration with Google Guice.ratpack.reactor Provides integration with the Project Reactor library.ratpack.retrofit Integration with Retrofit.ratpack.rx2 Provides integration with the RxJava library.ratpack.session Objects for providingSession
support.ratpack.spring.config ratpack.test Fixtures used for testing Ratpack applications (seeApplicationUnderTest
).ratpack.test.embed Support for creating embedded applications at test time, for testing Ratpack features and extensions.ratpack.test.exec ratpack.test.handling Test fixtures for exercisingHandler
implementations without start a fullEmbeddedApp
.ratpack.test.http Test fixtures that provide HTTP client interfaces to applications under test. -
-
Uses of Action in ratpack.config
Methods in ratpack.config with parameters of type Action Modifier and Type Method Description ConfigDataBuilder
ConfigDataBuilder. configureObjectMapper(Action<ObjectMapper> action)
Configures the object mapper used for binding configuration data to arbitrary objects.static ConfigData
ConfigData. of(ObjectMapper objectMapper, Action<? super ConfigDataBuilder> definition)
static ConfigData
ConfigData. of(Environment env, ObjectMapper objectMapper, Action<? super ConfigDataBuilder> definition)
Builds a new config data with the specified object mapper, from the given definition.static ConfigData
ConfigData. of(Environment env, Action<? super ConfigDataBuilder> definition)
Builds a new config data with the default object mapper, from the given definition.static ConfigData
ConfigData. of(Action<? super ConfigDataBuilder> definition)
ConfigDataBuilder
ConfigDataBuilder. onError(Action<? super Throwable> errorHandler)
Sets the error all that will be used for added configuration sources. -
Uses of Action in ratpack.consul
Methods in ratpack.consul with parameters of type Action Modifier and Type Method Description static com.google.common.io.ByteSource
RatpackConsulConfig. value(String key, com.orbitz.consul.option.QueryOptions queryOptions, Action<? super com.orbitz.consul.Consul.Builder> clientConfig)
Read the specified key as aByteSource
using the specified configuration to connection to Consul and the providedQueryOptions
.static com.google.common.io.ByteSource
RatpackConsulConfig. value(String key, Action<? super com.orbitz.consul.Consul.Builder> clientConfig)
Read the specified key as aByteSource
using the specified configuration to connection to Consul. -
Uses of Action in ratpack.core.handling
Methods in ratpack.core.handling with parameters of type Action Modifier and Type Method Description void
Context. byContent(Action<? super ByContentSpec> action)
Respond to the request based on the requested content type (i.e.static Handler
Handlers. byContent(Registry registry, Action<? super ByContentSpec> action)
Builds a content negotiating handler.void
Context. byMethod(Action<? super ByMethodSpec> action)
Respond to the request based on the request method.static Handler
Handlers. byMethod(Registry registry, Action<? super ByMethodSpec> action)
Builds a multi method handler.default Handler
Chain. chain(Action<? super Chain> action)
Constructs a handler using the given action to define a chain.static Handler
Handlers. chain(ServerConfig serverConfig, Registry registry, Action<? super Chain> action)
Builds a chain, backed by the given registry.static Handler
Handlers. chain(ServerConfig serverConfig, Action<? super Chain> action)
Builds a handler chain, with no backing registry.static Handler
Handlers. chain(Registry registry, Action<? super Chain> action)
Builds a chain, backed by the given registry.default Chain
Chain. files(Action<? super FileHandlerSpec> config)
Adds a handler that serves files from the file system.static Handler
Handlers. files(ServerConfig serverConfig, Action<? super FileHandlerSpec> config)
Creates a handler that serves files from the file system.default Chain
Chain. fileSystem(String path, Action<? super Chain> action)
Adds a handler to this chain that changes theFileSystemBinding
for the given handler chain.default Chain
Chain. host(String hostName, Action<? super Chain> action)
Adds a handler to the chain that delegates to the given handler chain if the request has aHost
header that matches the given value exactly.default Chain
Chain. insert(Action<? super Chain> action)
Inserts the given nested handler chain.static RequestLogger
RequestLogger. of(Action<? super RequestOutcome> action)
Creates a request logger with the given action as the implementation of theRequestLogger.log(RequestOutcome)
method.void
Context. onClose(Action<? super RequestOutcome> onClose)
Registers a callback to be notified when the request for this context is “closed” (i.e.default Chain
Chain. prefix(String prefix, Action<? super Chain> action)
Adds a handler that delegates to the given handlers if the relative path starts with the givenprefix
.static HandlerDecorator
HandlerDecorator. prependHandlers(Action<? super Chain> handlers)
A factory for decorator impls that effectively inserts the given chain before the “rest” of the handlers.default Chain
Chain. register(Registry registry, Action<? super Chain> action)
Adds a handler that inserts the given handler chain with the given registry viaContext.insert(Registry, Handler...)
.default Chain
Chain. register(Action<? super RegistrySpec> action)
Builds a new registry via the given action, then registers it viaChain.register(Registry)
.default Chain
Chain. register(Action<? super RegistrySpec> registryAction, Class<? extends Action<? super Chain>> action)
default Chain
Chain. register(Action<? super RegistrySpec> registryAction, Action<? super Chain> action)
Adds a handler that inserts the given handler chain with a registry built by the given action viaContext.insert(Registry, Handler...)
.default Chain
Chain. when(boolean test, Action<? super Chain> action)
Inlines the given chain iftest
istrue
.default Chain
Chain. when(boolean test, Action<? super Chain> onTrue, Action<? super Chain> onFalse)
Inlines the appropriate chain based on the giventest
.default Chain
Chain. when(Predicate<? super Context> test, Action<? super Chain> action)
default Chain
Chain. when(Predicate<? super Context> test, Action<? super Chain> onTrue, Action<? super Chain> onFalse)
Method parameters in ratpack.core.handling with type arguments of type Action Modifier and Type Method Description default Handler
Chain. chain(Class<? extends Action<? super Chain>> action)
default Chain
Chain. fileSystem(String path, Class<? extends Action<? super Chain>> action)
default Chain
Chain. host(String hostName, Class<? extends Action<? super Chain>> action)
default Chain
Chain. insert(Class<? extends Action<? super Chain>> action)
default Chain
Chain. prefix(String prefix, Class<? extends Action<? super Chain>> action)
static HandlerDecorator
HandlerDecorator. prependHandlers(Class<? extends Action<? super Chain>> handlers)
A factory for decorator impls that effectively inserts the given chain before the “rest” of the handlers.default Chain
Chain. register(Registry registry, Class<? extends Action<? super Chain>> action)
default Chain
Chain. register(Action<? super RegistrySpec> registryAction, Class<? extends Action<? super Chain>> action)
default Chain
Chain. when(boolean test, Class<? extends Action<? super Chain>> action)
Inlines the given chain iftest
istrue
.default Chain
Chain. when(boolean test, Class<? extends Action<? super Chain>> onTrue, Class<? extends Action<? super Chain>> onFalse)
Inlines the appropriate chain based on the giventest
.default Chain
Chain. when(Predicate<? super Context> test, Class<? extends Action<? super Chain>> action)
default Chain
Chain. when(Predicate<? super Context> test, Class<? extends Action<? super Chain>> onTrue, Class<? extends Action<? super Chain>> onFalse)
-
Uses of Action in ratpack.core.handling.direct
Methods in ratpack.core.handling.direct with parameters of type Action Modifier and Type Method Description void
DirectChannelAccess. takeOwnership(Action<Object> messageReceiver)
Signals that Ratpack should no longer manage this channel. -
Uses of Action in ratpack.core.http
Methods in ratpack.core.http with parameters of type Action Modifier and Type Method Description Response
Response. beforeSend(Action<? super Response> responseFinalizer)
Register a callback to execute with the response immediately before sending it to the client.default HttpUrlBuilder
HttpUrlBuilder. params(Action<? super com.google.common.collect.ImmutableMultimap.Builder<String,Object>> params)
Add some query params to the URL. -
Uses of Action in ratpack.core.http.client
Methods in ratpack.core.http.client that return Action Modifier and Type Method Description Action<? super SSLParameters>
RequestSpec. getSslParams()
Get additional configuration, such as SNI names, for the TLS/SSL connection to the server.Methods in ratpack.core.http.client with parameters of type Action Modifier and Type Method Description HttpClientSpec
HttpClientSpec. addressResolver(Action<? super io.netty.resolver.dns.DnsNameResolverBuilder> resolver)
Specifies a custom name resolver to use.RequestSpec
RequestSpec. body(Action<? super RequestSpec.Body> action)
Executes the given action with therequest body
.HttpClient
HttpClient. copyWith(Action<? super HttpClientSpec> action)
Create a new HttpClient by appending the provided configuration to this client.HttpClientSpec
HttpClientSpec. errorIntercept(Action<? super Throwable> interceptor)
Add an interceptor for errors thrown by this client (eg.void
StreamedResponse. forwardTo(Response response, Action<? super MutableHeaders> headerMutator)
Stream this received response out to the given server response.Promise<ReceivedResponse>
HttpClient. get(URI uri, Action<? super RequestSpec> action)
An asynchronous method to do a GET HTTP request, the URL and all details of the request are configured by the Action acting on the RequestSpec, but the method will be defaulted to a GET.RequestSpec
RequestSpec. headers(Action<? super MutableHeaders> action)
This method can be used to buffer changes to the headers.static HttpClient
HttpClient. of(Action<? super HttpClientSpec> action)
Creates a new HTTP client.Promise<ReceivedResponse>
HttpClient. post(URI uri, Action<? super RequestSpec> action)
An asynchronous method to do a POST HTTP request, the URL and all details of the request are configured by the Action acting on the RequestSpec, but the method will be defaulted to a POST.HttpClientSpec
HttpClientSpec. proxy(Action<? super ProxySpec> proxy)
Configure a HTTP proxy for outgoing calls from this client.Promise<ReceivedResponse>
HttpClient. request(URI uri, Action<? super RequestSpec> action)
An asynchronous method to do a HTTP request, the URL and all details of the request are configured by the Action acting on the RequestSpec.HttpClientSpec
HttpClientSpec. requestIntercept(Action<? super RequestSpec> interceptor)
Add an interceptor for all requests handled by this client.Promise<StreamedResponse>
HttpClient. requestStream(URI uri, Action<? super RequestSpec> requestConfigurer)
An asynchronous method to do a HTTP request, the URL and all details of the request are configured by the Action acting on the RequestSpec, the received response content will be streamed.HttpClientSpec
HttpClientSpec. responseIntercept(Action<? super HttpResponse> interceptor)
Add an interceptor for all responses returned by this client.RequestSpec
RequestSpec. sslParams(Action<? super SSLParameters> action)
Sets additional configuration, such as SNI names, for the TLS/SSL connection to the server.RequestSpec.Body
RequestSpec.Body. stream(Action<? super OutputStream> action)
Specifies the request body by writing to an output stream.Method parameters in ratpack.core.http.client with type arguments of type Action Modifier and Type Method Description RequestSpec
RequestSpec. onRedirect(Function<? super ReceivedResponse,Action<? super RequestSpec>> function)
Specifies a function to invoke when a redirectable response is received. -
Uses of Action in ratpack.core.impose
Methods in ratpack.core.impose with parameters of type Action Modifier and Type Method Description static Impositions
Impositions. of(Action<? super ImpositionsSpec> consumer)
Creates an impositions instance of the given imposition objects. -
Uses of Action in ratpack.core.logging
Methods in ratpack.core.logging with parameters of type Action Modifier and Type Method Description static MDCInterceptor
MDCInterceptor. withInit(Action<? super Execution> init)
Creates an interceptor with the given initialisation action. -
Uses of Action in ratpack.core.path
Methods in ratpack.core.path with parameters of type Action Modifier and Type Method Description static PathBinder
PathBinder. of(boolean exhaustive, Action<? super PathBinderBuilder> action)
Builds a path binder programmatically. -
Uses of Action in ratpack.core.render
Methods in ratpack.core.render that return Action Modifier and Type Method Description default Action<RegistrySpec>
RenderableDecorator. register()
A registration action, typically used withRegistrySpec.with(Action)
. -
Uses of Action in ratpack.core.server
Methods in ratpack.core.server with parameters of type Action Modifier and Type Method Description ServerConfigBuilder
ServerConfigBuilder. configureObjectMapper(Action<ObjectMapper> action)
Configures the object mapper used for binding configuration data to arbitrary objects.default URI
PublicAddress. get(Action<? super HttpUrlBuilder> action)
Creates a URL by building a URL based on the public address.default RatpackServerSpec
RatpackServerSpec. handlers(Action<? super Chain> handlers)
Sets the root handler to the chain specified by the given action.static RatpackServer
RatpackServer. of(Action<? super RatpackServerSpec> definition)
Creates a new, unstarted, Ratpack server from the given definition.static ServerConfig
ServerConfig. of(Action<? super ServerConfigBuilder> action)
ServerConfigBuilder
ServerConfigBuilder. onError(Action<? super Throwable> errorHandler)
Sets the error all that will be used for added configuration sources.default RatpackServerSpec
RatpackServerSpec. registryOf(Action<? super RegistrySpec> action)
Builds the user registry via the given spec action.default RatpackServerSpec
RatpackServerSpec. serverConfig(Action<? super ServerConfigBuilder> action)
ServerConfigBuilder
ServerConfigBuilder. ssl(io.netty.handler.ssl.SslContext sslContext, Action<? super io.netty.util.DomainWildcardMappingBuilder<io.netty.handler.ssl.SslContext>> sniConfiguration)
Configures the SSL contexts to use based on the client requested domain if the application serves content over HTTPS.static RatpackServer
RatpackServer. start(Action<? super RatpackServerSpec> definition)
Convenience method todefine
andRatpackServer.start()
the server in one go. -
Uses of Action in ratpack.core.service
Methods in ratpack.core.service with parameters of type Action Modifier and Type Method Description static Service
Service. shutdown(String name, Action<? super StopEvent> action)
Creates a service that executes the given action as theService.onStop(StopEvent)
implementation.static Service
Service. startup(String name, Action<? super StartEvent> action)
Creates a service that executes the given action as theService.onStart(StartEvent)
implementation. -
Uses of Action in ratpack.core.sse.client
Methods in ratpack.core.sse.client with parameters of type Action Modifier and Type Method Description Promise<ServerSentEventResponse>
ServerSentEventClient. request(URI uri, Action<? super RequestSpec> action)
Makes a request for an event stream to the given location. -
Uses of Action in ratpack.core.websocket
Methods in ratpack.core.websocket with parameters of type Action Modifier and Type Method Description void
WebSocketConnector. connect(Action<? super WebSocketSpec<T>> specAction)
WebSocketSpec<T>
WebSocketSpec. onClose(Action<WebSocketClose<T>> action)
WebSocketSpec<T>
WebSocketSpec. onMessage(Action<WebSocketMessage<T>> action)
-
Uses of Action in ratpack.dropwizard.metrics
Methods in ratpack.dropwizard.metrics with parameters of type Action Modifier and Type Method Description DropwizardMetricsConfig
DropwizardMetricsConfig. byteBufAllocator(Action<? super ByteBufAllocatorConfig> configure)
Configure the byte buf allocator metric set.DropwizardMetricsConfig
DropwizardMetricsConfig. console(Action<? super ConsoleConfig> configure)
Configure the console metrics publisher.DropwizardMetricsConfig
DropwizardMetricsConfig. csv(Action<? super CsvConfig> configure)
Configure the csv metrics publisher.DropwizardMetricsConfig
DropwizardMetricsConfig. graphite(Action<? super GraphiteConfig> configure)
Configure the Graphite metrics publisher.DropwizardMetricsConfig
DropwizardMetricsConfig. httpClient(Action<? super HttpClientConfig> configure)
Configure the http client metric set.DropwizardMetricsConfig
DropwizardMetricsConfig. jmx(Action<? super JmxConfig> configure)
Configure the JMX metrics publisher.DropwizardMetricsConfig
DropwizardMetricsConfig. slf4j(Action<? super Slf4jConfig> configure)
Configure the Slf4j logger metrics publisher.DropwizardMetricsConfig
DropwizardMetricsConfig. webSocket(Action<? super WebsocketConfig> configure)
Configure the websockets metrics broadcaster. -
Uses of Action in ratpack.exec
Methods in ratpack.exec with parameters of type Action Modifier and Type Method Description ExecControllerSpec
ExecControllerSpec. blocking(Action<? super ExecControllerSpec.BlockingSpec> definition)
Configures the default executor for blocking (i.e.default Promise<T>
Promise. blockingOp(Action<? super T> action)
Executes the given action with the promise value, on a blocking thread.ExecControllerSpec
ExecControllerSpec. compute(Action<? super ExecControllerSpec.ComputeSpec> definition)
Configures the default executor for computation (i.e.default Promise<T>
Promise. defer(Action<? super Runnable> releaser)
Defers the subscription ofthis
promise until later.default Promise<T>
Promise. fork(Action<? super ExecSpec> execSpec)
Forks a new execution and subscribes to this promise, returning a promise for its value.default Operation
Operation. mapError(Action<? super Throwable> action)
Convert an error to a success or different error.default Promise<T>
Promise. next(Action<? super T> action)
Executes the provided, potentially asynchronous,Action
with the promised value as input.static ExecController
ExecController. of(Action<? super ExecControllerSpec> definition)
Construct a new execution controller from the provided specification.ExecSpec
ExecSpec. onComplete(Action<? super Execution> onComplete)
Specifies the completion callback for the execution.ExecStarter
ExecStarter. onComplete(Action<? super Execution> onComplete)
Specifies the completion callback for the execution.default Downstream<T>
Downstream. onError(Action<? super Throwable> action)
Wrap this downstream, using the given action as the implementation of theDownstream.error(Throwable)
method.ExecSpec
ExecSpec. onError(Action<? super Throwable> onError)
Specify the top level error handler for the execution.ExecStarter
ExecStarter. onError(Action<? super Throwable> onError)
Specify the top level error handler for the execution.default <E extends Throwable>
OperationOperation. onError(Class<E> errorType, Action<? super E> errorHandler)
Specifies the action to take if the an error of the given type occurs trying to perform the operation.default Operation
Operation. onError(Action<? super Throwable> onError)
Operation
Operation. onError(Predicate<? super Throwable> predicate, Action<? super Throwable> errorHandler)
Specifies the action to take if the an error occurs performing the operation that the given predicate applies to.default <E extends Throwable>
Promise<T>Promise. onError(Class<E> errorType, Action<? super E> errorHandler)
Specifies the action to take if the an error of the given type occurs trying to produce the promised value.default Promise<T>
Promise. onError(Action<? super Throwable> errorHandler)
Specifies the action to take if an error occurs trying to produce the promised value.default Promise<T>
Promise. onError(Predicate<? super Throwable> predicate, Action<? super Throwable> errorHandler)
Specifies the action to take if the an error occurs trying to produce the promised value, that the given predicate applies to.ExecSpec
ExecSpec. onStart(Action<? super Execution> onStart)
Specifies an action to be taken just before the execution starts.ExecStarter
ExecStarter. onStart(Action<? super Execution> onStart)
Specifies an action to be taken just before the execution starts.default <O> Downstream<O>
Downstream. onSuccess(Action<? super O> action)
Wrap this downstream, using the given action as the implementation of theDownstream.success(T)
method.default Operation
Promise. operation(Action<? super T> action)
Converts this promise to an operation which is effectivelyaction
.ExecSpec
ExecSpec. register(Action<? super RegistrySpec> action)
Populates the execution's registry.ExecStarter
ExecStarter. register(Action<? super RegistrySpec> action)
Populates the execution's registry.default void
Promise. result(Action<? super ExecResult<T>> resultHandler)
Consume the promised value as aResult
.default Promise<T>
Promise. route(Predicate<? super T> predicate, Action<? super T> action)
Allows the promised value to be handled specially if it meets the given predicate, instead of being handled by the promise subscriber.void
ExecStarter. start(Action<? super Execution> initialExecutionSegment)
Starts the execution, with the given action as the initial segment.void
Promise. then(Action<? super T> then)
Specifies what should be done with the promised object when it becomes available.default Promise<T>
Promise. time(Action<? super Duration> action)
Emits the time taken from when the promise is subscribed to to when the result is available.default Operation
Operation. wiretap(Action<? super Optional<? extends Throwable>> action)
default Promise<T>
Promise. wiretap(Action<? super Result<T>> listener)
Registers a listener for the promise outcome. -
Uses of Action in ratpack.exec.registry
Methods in ratpack.exec.registry with parameters of type Action Modifier and Type Method Description static Registry
Registry. of(Action<? super RegistrySpec> action)
Builds a registry from the given action.default RegistryBuilder
RegistryBuilder. with(Action<? super RegistrySpec> action)
default RegistrySpec
RegistrySpec. with(Action<? super RegistrySpec> action)
Executes the given action withthis
. -
Uses of Action in ratpack.exec.stream
Methods in ratpack.exec.stream with parameters of type Action Modifier and Type Method Description static <T> TransformablePublisher<T>
Streams. batch(int batchSize, Publisher<T> publisher, Action<? super T> disposer)
Batches and serialised demand.default TransformablePublisher<T>
TransformablePublisher. batch(int batchSize, Action<? super T> disposer)
static <T> TransformablePublisher<T>
Streams. bindExec(Publisher<T> publisher, Action<? super T> disposer)
Binds the given publisher to the currentExecution
.default TransformablePublisher<T>
TransformablePublisher. bindExec(Action<? super T> disposer)
static <T> TransformablePublisher<T>
Streams. concat(Iterable<? extends Publisher<? extends T>> publishers, Action<? super T> disposer)
Returns a publisher that aggregates the given publishers into a single stream of elements, without interleaving them.static <T> TransformablePublisher<T>
Streams. fanOut(Publisher<? extends Iterable<? extends T>> publisher, Action<? super T> disposer)
Returns a publisher that publishes each element from Collections that are produced from the given input publisher.static <T> TransformablePublisher<T>
Streams. flatten(Publisher<? extends Publisher<T>> publisher, Action<? super T> disposer)
Creates a single publisher from a publisher of publishers.static <T> TransformablePublisher<T>
Streams. fork(Publisher<T> publisher, Action<? super ExecSpec> execConfig, Action<? super T> disposer)
Consumes the given publisher eagerly in a forked execution, buffering results until ready to be consumed by this execution.default TransformablePublisher<T>
TransformablePublisher. fork(Action<? super ExecSpec> execConfig, Action<? super T> disposer)
Consumes the given publisher eagerly in a forked execution, buffering results until ready to be consumed by this execution.static <T> TransformablePublisher<T>
Streams. gate(Publisher<T> publisher, Action<? super Runnable> valveReceiver)
Allows requests from the subscriber of the return publisher to be withheld from the given publisher until an externally defined moment.default TransformablePublisher<T>
TransformablePublisher. gate(Action<? super Runnable> valveReceiver)
default <O> WriteStream<O>
WriteStream. itemMap(Subscription subscription, Action<? super O> itemMapper)
Creates a new write stream that passes error and complete signals on to this stream, but passes items to the given action.static <T> TransformablePublisher<T>
Streams. wiretap(Publisher<T> publisher, Action<? super StreamEvent<T>> listener)
Allows listening to the events of the given publisher as they flow to subscribers.default TransformablePublisher<T>
TransformablePublisher. wiretap(Action<? super StreamEvent<T>> listener)
-
Uses of Action in ratpack.exec.util
Methods in ratpack.exec.util with parameters of type Action Modifier and Type Method Description ParallelBatch<T>
ParallelBatch. execInit(Action<? super Execution> execInit)
Specifies an initializer for each forked execution. -
Uses of Action in ratpack.exec.util.retry
Methods in ratpack.exec.util.retry with parameters of type Action Modifier and Type Method Description static AttemptRetryPolicy
AttemptRetryPolicy. of(Action<? super AttemptRetryPolicyBuilder> definition)
Builds a new attempt based retry policy from the given definition.static DurationRetryPolicy
DurationRetryPolicy. of(Action<? super DurationRetryPolicyBuilder> definition)
Builds a new duration based retry policy from the given definition. -
Uses of Action in ratpack.func
Methods in ratpack.func that return Action Modifier and Type Method Description default Action<Object>
Block. action()
Creates anAction
from this block, where the argument is ignored.default <O extends T>
Action<O>Action. append(Action<? super O> action)
Returns a new action that executes this action and then the given action.static Action<Throwable>
Action. beforeThrow(Action<? super Throwable> action)
Creates an exception-taking action that executes the given action before throwing the exception.static Action<Throwable>
Action. beforeThrow(Block block)
Creates an exception-taking action that executes the given block before throwing the exception.static <I> Action<I>
Action. conditional(Action<? super I> onElse, Action<? super Action.ConditionalSpec<I>> conditions)
Creates an action that delegates based on the specified conditions.static <I> Action<I>
Action. conditional(Action<? super Action.ConditionalSpec<I>> conditions)
Creates an action that delegates based on the specified conditions.static <T> Action<T>
Action. from(Consumer<T> consumer)
Creates an action from a JDK consumer.static <T> Action<T>
Action. ignoreArg(Block block)
static <T> Action<T>
Action. join(Action<? super T>... actions)
Returns a new action that executes the given actions in order.static <T> Action<T>
Action. noop()
Returns an action that does precisely nothing.static <T> Action<? super T>
Action. noopIfNull(Action<T> action)
If the given action isnull
, returnsnoop()
, otherwise returns the given action.default <O extends T>
Action<O>Action. prepend(Action<? super O> action)
Returns a new action that executes the given action and then this action.static Action<Throwable>
Action. suppressAndThrow(Throwable toSuppress)
An action that receives a throwable to thrown, suppressing the given value.static Action<Throwable>
Action. throwException()
Returns an action that receives a throwable and immediately throws it.static <T> Action<T>
Action. throwException(Throwable throwable)
Returns an action that immediately throws the given exception.static <I> Action<I>
Action. when(Predicate<? super I> predicate, Action<? super I> action)
Creates an action that delegates to the given action if the given predicate applies, else delegates tonoop()
.static <I> Action<I>
Action. when(Predicate<? super I> predicate, Action<? super I> onTrue, Action<? super I> onFalse)
Creates an action that delegates to the first action if the given predicate applies, else the second action.Methods in ratpack.func with parameters of type Action Modifier and Type Method Description default <O extends T>
Action<O>Action. append(Action<? super O> action)
Returns a new action that executes this action and then the given action.static Action<Throwable>
Action. beforeThrow(Action<? super Throwable> action)
Creates an exception-taking action that executes the given action before throwing the exception.static <I> Action<I>
Action. conditional(Action<? super I> onElse, Action<? super Action.ConditionalSpec<I>> conditions)
Creates an action that delegates based on the specified conditions.static <I> Action<I>
Action. conditional(Action<? super Action.ConditionalSpec<I>> conditions)
Creates an action that delegates based on the specified conditions.static <I,O>
Function<I,O>Function. conditional(Action<? super Function.ConditionalSpec<I,O>> conditions)
Creates a function that delegates based on the specified conditions.static <I,O>
Function<I,O>Function. conditional(Function<? super I,? extends O> onElse, Action<? super Function.ConditionalSpec<I,O>> conditions)
Creates a function that delegates based on the specified conditions.static <T> Action<T>
Action. join(Action<? super T>... actions)
Returns a new action that executes the given actions in order.static <T> Action<? super T>
Action. noopIfNull(Action<T> action)
If the given action isnull
, returnsnoop()
, otherwise returns the given action.default <O extends T>
Action<O>Action. prepend(Action<? super O> action)
Returns a new action that executes the given action and then this action.static <T> void
Exceptions. uncheck(T input, Action<T> action)
Executes the given action with the provided input argument, unchecking any exceptions it throws.static <T> T
Action. uncheckedWith(T t, Action<? super T> action)
Likewith(Object, Action)
, but unchecks any exceptions thrown by the action viaExceptions.uncheck(Throwable)
.Action.ConditionalSpec<I>
Action.ConditionalSpec. when(Predicate<? super I> predicate, Action<? super I> action)
static <I> Action<I>
Action. when(Predicate<? super I> predicate, Action<? super I> action)
Creates an action that delegates to the given action if the given predicate applies, else delegates tonoop()
.static <I> Action<I>
Action. when(Predicate<? super I> predicate, Action<? super I> onTrue, Action<? super I> onFalse)
Creates an action that delegates to the first action if the given predicate applies, else the second action.static <T> T
Action. with(T t, Action<? super T> action)
Executes the action with the given argument, then returns the argument. -
Uses of Action in ratpack.groovy
Methods in ratpack.groovy that return Action Modifier and Type Method Description static Action<? super RatpackServerSpec>
Groovy.Script. app()
Creates an application defining action from a Groovy script named "ratpack.groovy".static Action<? super RatpackServerSpec>
Groovy.Script. app(boolean compileStatic)
Creates an application defining action from a Groovy script named "ratpack.groovy".static Action<? super RatpackServerSpec>
Groovy.Script. app(boolean compileStatic, String... scriptPaths)
Creates an application defining action from a Groovy script.static Action<? super RatpackServerSpec>
Groovy.Script. app(boolean compileStatic, Path script)
Creates an application defining action from a Groovy script.static Action<? super RatpackServerSpec>
Groovy.Script. app(Path script)
Creates an application defining action from a Groovy script.static Action<? super RatpackServerSpec>
Groovy.Script. appWithArgs(boolean compileStatic, String[] scriptPaths, String... args)
Creates an application defining action from a Groovy script.static Action<? super RatpackServerSpec>
Groovy.Script. appWithArgs(boolean compileStatic, Path script, String... args)
Creates an application defining action from a Groovy script.static Action<? super RatpackServerSpec>
Groovy.Script. appWithArgs(String... args)
Creates an application defining action from a Groovy script named "ratpack.groovy".static Action<Chain>
Groovy. chain(Closure<?> closure)
Creates a chain action implementation from the given closure.static Action<Chain>
Groovy. chainAction(Closure<?> closure)
Creates a chain action based on the given closure.Methods in ratpack.groovy with parameters of type Action Modifier and Type Method Description static MarkupTemplate
Groovy. groovyMarkupTemplate(String id, String type, Action<? super com.google.common.collect.ImmutableMap.Builder<String,Object>> modelBuilder)
Creates arenderable
Groovy based markup template.static MarkupTemplate
Groovy. groovyMarkupTemplate(String id, Action<? super com.google.common.collect.ImmutableMap.Builder<String,Object>> modelBuilder)
Creates arenderable
Groovy based markup template, using the default content type. -
Uses of Action in ratpack.groovy.handling
Classes in ratpack.groovy.handling that implement Action Modifier and Type Class Description class
GroovyChainAction
A convenience super class for a standalone implementation of aAction<GroovyChain>
.Methods in ratpack.groovy.handling with parameters of type Action Modifier and Type Method Description default GroovyChain
GroovyChain. files(Action<? super FileHandlerSpec> config)
Adds a handler that serves files from the file system.default GroovyChain
GroovyChain. fileSystem(String path, Action<? super Chain> action)
Adds a handler to this chain that changes theFileSystemBinding
for the given handler chain.default GroovyChain
GroovyChain. host(String hostName, Action<? super Chain> action)
Adds a handler to the chain that delegates to the given handler chain if the request has aHost
header that matches the given value exactly.default GroovyChain
GroovyChain. insert(Action<? super Chain> action)
Inserts the given nested handler chain.default GroovyChain
GroovyChain. prefix(String prefix, Action<? super Chain> action)
Adds a handler that delegates to the given handlers if the relative path starts with the givenprefix
.default GroovyChain
GroovyChain. register(Registry registry, Action<? super Chain> action)
Adds a handler that inserts the given handler chain with the given registry viaContext.insert(Registry, Handler...)
.default GroovyChain
GroovyChain. register(Action<? super RegistrySpec> action)
Builds a new registry via the given action, then registers it viaChain.register(Registry)
.default GroovyChain
GroovyChain. register(Action<? super RegistrySpec> registryAction, Closure<?> handler)
default GroovyChain
GroovyChain. register(Action<? super RegistrySpec> registryAction, Class<? extends Action<? super Chain>> action)
default GroovyChain
GroovyChain. register(Action<? super RegistrySpec> registryAction, Action<? super Chain> chainAction)
Adds a handler that inserts the given handler chain with a registry built by the given action viaContext.insert(Registry, Handler...)
.default GroovyChain
GroovyChain. when(boolean test, Action<? super Chain> action)
Inlines the given chain iftest
istrue
.default GroovyChain
GroovyChain. when(boolean test, Action<? super Chain> onTrue, Action<? super Chain> onFalse)
Inlines the appropriate chain based on the giventest
.default GroovyChain
GroovyChain. when(Closure<?> test, Action<? super Chain> chain)
default GroovyChain
GroovyChain. when(Closure<?> test, Action<? super Chain> ifChain, Action<? super Chain> elseChain)
default GroovyChain
GroovyChain. when(Predicate<? super Context> test, Action<? super Chain> action)
default GroovyChain
GroovyChain. when(Predicate<? super Context> test, Action<? super Chain> onTrue, Action<? super Chain> onFalse)
Method parameters in ratpack.groovy.handling with type arguments of type Action Modifier and Type Method Description default GroovyChain
GroovyChain. fileSystem(String path, Class<? extends Action<? super Chain>> action)
default GroovyChain
GroovyChain. host(String hostName, Class<? extends Action<? super Chain>> action)
default GroovyChain
GroovyChain. insert(Class<? extends Action<? super Chain>> action)
default GroovyChain
GroovyChain. prefix(String prefix, Class<? extends Action<? super Chain>> action)
default GroovyChain
GroovyChain. register(Registry registry, Class<? extends Action<? super Chain>> action)
default GroovyChain
GroovyChain. register(Action<? super RegistrySpec> registryAction, Class<? extends Action<? super Chain>> action)
default GroovyChain
GroovyChain. when(boolean test, Class<? extends Action<? super Chain>> action)
Inlines the given chain iftest
istrue
.default GroovyChain
GroovyChain. when(boolean test, Class<? extends Action<? super Chain>> onTrue, Class<? extends Action<? super Chain>> onFalse)
Inlines the appropriate chain based on the giventest
.default GroovyChain
GroovyChain. when(Closure<?> test, Class<? extends Action<? super Chain>> action)
default GroovyChain
GroovyChain. when(Closure<?> test, Class<? extends Action<? super Chain>> ifAction, Class<? extends Action<? super Chain>> elseAction)
default GroovyChain
GroovyChain. when(Predicate<? super Context> test, Class<? extends Action<? super Chain>> action)
default GroovyChain
GroovyChain. when(Predicate<? super Context> test, Class<? extends Action<? super Chain>> onTrue, Class<? extends Action<? super Chain>> onFalse)
-
Uses of Action in ratpack.groovy.server
Methods in ratpack.groovy.server with parameters of type Action Modifier and Type Method Description GroovyRatpackServerSpec
GroovyRatpackServerSpec. serverConfig(Action<? super ServerConfigBuilder> action)
-
Uses of Action in ratpack.groovy.test.handling
Methods in ratpack.groovy.test.handling with parameters of type Action Modifier and Type Method Description static HandlingResult
GroovyRequestFixture. handle(Action<? super Chain> handlers, Closure<?> closure)
Unit test a chain ofhandlers
.GroovyRequestFixture
GroovyRequestFixture. registry(Action<? super RegistrySpec> action)
Configures the context registry.GroovyRequestFixture
GroovyRequestFixture. serverConfig(Action<? super ServerConfigBuilder> action)
Configures the server config to have no base dir and given configuration. -
Uses of Action in ratpack.guice
Methods in ratpack.guice that return Action Modifier and Type Method Description Action<? super BindingsSpec>
BindingsImposition. getBindings()
The bindings to add/override.Methods in ratpack.guice with parameters of type Action Modifier and Type Method Description BindingsSpec
BindingsSpec. binder(Action<? super com.google.inject.Binder> action)
Adds bindings by directly configuring aBinder
.void
ConfigurableModule. configure(Action<? super T> configurer)
Registers the configuration action.<C,T extends ConfigurableModule<C>>
BindingsSpecBindingsSpec. module(Class<T> moduleClass, Action<? super C> configurer)
Adds the bindings from the given configurable module.<C> BindingsSpec
BindingsSpec. module(ConfigurableModule<C> module, Action<? super C> configurer)
Adds the bindings from the given configurable module.<C,T extends ConfigurableModule<C>>
BindingsSpecBindingsSpec. moduleConfig(Class<T> moduleClass, C config, Action<? super C> configurer)
Adds the bindings from the given configurable module.<C> BindingsSpec
BindingsSpec. moduleConfig(ConfigurableModule<C> module, C config, Action<? super C> configurer)
Adds the bindings from the given configurable module.default <T> BindingsSpec
BindingsSpec. multiBinder(com.google.common.reflect.TypeToken<T> type, Action<? super com.google.inject.multibindings.Multibinder<T>> action)
default <T> BindingsSpec
BindingsSpec. multiBinder(com.google.inject.TypeLiteral<T> type, Action<? super com.google.inject.multibindings.Multibinder<T>> action)
default <T> BindingsSpec
BindingsSpec. multiBinder(Class<T> type, Action<? super com.google.inject.multibindings.Multibinder<T>> action)
static BindingsImposition
BindingsImposition. of(Action<? super BindingsSpec> bindings)
Creates a new bindings imposition of the given bindings.static Function<Registry,Registry>
Guice. registry(com.google.inject.Injector parentInjector, Action<? super BindingsSpec> bindings)
static Function<Registry,Registry>
Guice. registry(Action<? super BindingsSpec> bindings)
-
Uses of Action in ratpack.reactor
Methods in ratpack.reactor with parameters of type Action Modifier and Type Method Description static <T> Flux<T>
ReactorRatpack. fork(Flux<T> flux, Action<? super RegistrySpec> doWithRegistrySpec)
A variant ofReactorRatpack.fork(reactor.core.publisher.Flux<T>)
that allows access to the registry of the forked execution inside anAction
.static <T> Flux<T>
ReactorRatpack. forkEach(Flux<T> flux, Action<? super RegistrySpec> doWithRegistrySpec)
A variant ofReactorRatpack.forkEach(reactor.core.publisher.Flux<T>)
that allows access to the registry of each forked execution inside anAction
. -
Uses of Action in ratpack.retrofit
Methods in ratpack.retrofit with parameters of type Action Modifier and Type Method Description RatpackRetrofit.Builder
RatpackRetrofit.Builder. configure(Action<? super Retrofit.Builder> builderAction)
Configure the underlyingRetrofit.Builder
instance. -
Uses of Action in ratpack.rx2
Methods in ratpack.rx2 with parameters of type Action Modifier and Type Method Description static <T> Observable<T>
RxRatpack. fork(Observable<T> observable, Action<? super RegistrySpec> registrySpec)
A variant ofRxRatpack.fork(io.reactivex.Observable<T>)
that allows access to the registry of the forked execution inside anAction
.static <T> Observable<T>
RxRatpack. forkEach(Observable<T> observable, Action<? super RegistrySpec> registrySpec)
A variant ofRxRatpack.forkEach(io.reactivex.Observable<T>)
that allows access to the registry of each forked execution inside anAction
. -
Uses of Action in ratpack.session
Methods in ratpack.session that return Action Modifier and Type Method Description static Action<com.google.inject.Binder>
SessionModule. memoryStore(Consumer<? super com.google.common.cache.CacheBuilder<io.netty.util.AsciiString,io.netty.buffer.ByteBuf>> config)
A builder for an alternative cache for the default in memory store. -
Uses of Action in ratpack.spring.config
Methods in ratpack.spring.config that return Action Modifier and Type Method Description Action<BindingsSpec>
RatpackServerCustomizer. getBindings()
Action<BindingsSpec>
RatpackServerCustomizerAdapter. getBindings()
Action<ServerConfigBuilder>
RatpackServerCustomizer. getServerConfig()
Action<ServerConfigBuilder>
RatpackServerCustomizerAdapter. getServerConfig()
Methods in ratpack.spring.config that return types with arguments of type Action Modifier and Type Method Description List<Action<Chain>>
RatpackServerCustomizer. getHandlers()
List<Action<Chain>>
RatpackServerCustomizerAdapter. getHandlers()
-
Uses of Action in ratpack.test
Methods in ratpack.test with parameters of type Action Modifier and Type Method Description default void
CloseableApplicationUnderTest. test(Action<? super TestHttpClient> action)
Provides the given action with atest http client
for this application, then closes this application. -
Uses of Action in ratpack.test.embed
Methods in ratpack.test.embed with parameters of type Action Modifier and Type Method Description static EmbeddedApp
EmbeddedApp. fromHandlers(Action<? super Chain> action)
Creates an embedded application with a default launch config (no base dir, ephemeral port) and the given handler chain.static EmbeddedApp
EmbeddedApp. fromServer(ServerConfigBuilder serverConfig, Action<? super RatpackServerSpec> definition)
Creates an embedded application using the given server config, and server creating function.static EmbeddedApp
EmbeddedApp. fromServer(ServerConfig serverConfig, Action<? super RatpackServerSpec> definition)
Creates an embedded application using the given server config, and server creating function.static EmbeddedApp
EmbeddedApp. of(Action<? super RatpackServerSpec> definition)
Creates an embedded application from the given function.default void
EphemeralBaseDir. use(Action<? super EphemeralBaseDir> action)
Executes the given action with this base dir, then closes this base dir. -
Uses of Action in ratpack.test.exec
Methods in ratpack.test.exec with parameters of type Action Modifier and Type Method Description default void
ExecHarness. execute(Action<? super RegistrySpec> registry, Function<? super Execution,? extends Operation> function)
static void
ExecHarness. executeSingle(Action<? super RegistrySpec> registry, Function<? super Execution,? extends Operation> function)
static ExecHarness
ExecHarness. harness(Action<? super ExecControllerSpec> definition)
Create a harness that is backed by an execution controller with the provided configurationdefault void
ExecHarness. run(Action<? super Execution> action)
Initiates an execution and blocks until it completes.void
ExecHarness. run(Action<? super RegistrySpec> registry, Action<? super Execution> action)
Initiates an execution and blocks until it completes.static void
ExecHarness. runSingle(Action<? super Execution> action)
Convenient form ofExecHarness.run(Action)
that creates and closes a harness for the run.static void
ExecHarness. runSingle(Action<? super RegistrySpec> registry, Action<? super Execution> action)
Convenient form ofExecHarness.run(Action, Action)
that creates and closes a harness for the run.<T> ExecResult<T>
ExecHarness. yield(Action<? super RegistrySpec> registry, Function<? super Execution,? extends Promise<T>> func)
Synchronously returns a promised value.static <T> ExecResult<T>
ExecHarness. yieldSingle(Action<? super RegistrySpec> registry, Function<? super Execution,? extends Promise<T>> func)
Creates an exec harness,executes
the given function with it before closing it, then returning execution result. -
Uses of Action in ratpack.test.handling
Methods in ratpack.test.handling with parameters of type Action Modifier and Type Method Description static HandlingResult
RequestFixture. handle(Handler handler, Action<? super RequestFixture> action)
Unit test a singleHandler
.static HandlingResult
RequestFixture. handle(Action<? super Chain> chainAction, Action<? super RequestFixture> requestFixtureAction)
Unit test aHandler
chain.HandlingResult
RequestFixture. handleChain(Action<? super Chain> chainAction)
Similar toRequestFixture.handle(Handler)
, but for testing a handler chain.RequestFixture
RequestFixture. registry(Action<? super RegistrySpec> action)
Configures the context registry.RequestFixture
RequestFixture. serverConfig(Action<? super ServerConfigBuilder> action)
Configures the server config to have no base dir and given configuration. -
Uses of Action in ratpack.test.http
Methods in ratpack.test.http with parameters of type Action Modifier and Type Method Description TestHttpClient
TestHttpClient. params(Action<? super com.google.common.collect.ImmutableMultimap.Builder<String,Object>> params)
Specify query parameters to be included with outgoing requests from this client.ReceivedResponse
TestHttpClient. request(String path, Action<? super RequestSpec> requestAction)
Executes the request as specified by the providedRequestSpec
against the provided path.ReceivedResponse
TestHttpClient. request(Action<? super RequestSpec> requestAction)
Executes the request as specified by the providedRequestSpec
.TestHttpClient
TestHttpClient. requestSpec(Action<? super RequestSpec> requestAction)
Configure the settings for outgoing requests from this client.static TestHttpClient
TestHttpClient. testHttpClient(ApplicationUnderTest applicationUnderTest, Action<? super RequestSpec> requestConfigurer)
A method to create an instance of the default implementation of TestHttpClient.
-