fixing scaladoc warnings reported by jenkins

This commit is contained in:
Wojciech Langiewicz 2016-03-10 11:31:18 +01:00
parent 87113f9b14
commit afce1b7529
26 changed files with 74 additions and 73 deletions

View file

@ -11,7 +11,7 @@ import scala.concurrent.duration.Duration
/** /**
* Wraps a [[org.apache.camel.model.ProcessorDefinition]]. * Wraps a [[org.apache.camel.model.ProcessorDefinition]].
* There is an implicit conversion in the [[akka.camel]] package object that converts a `ProcessorDefinition` into `this` type. * There is an implicit conversion in the `akka.camel` package object that converts a `ProcessorDefinition` into `this` type.
* Because of this conversion, it is possible to use an [[akka.actor.ActorRef]] as a `to` parameter in building a route: * Because of this conversion, it is possible to use an [[akka.actor.ActorRef]] as a `to` parameter in building a route:
* {{{ * {{{
* class TestRoute(system: ActorSystem) extends RouteBuilder { * class TestRoute(system: ActorSystem) extends RouteBuilder {

View file

@ -339,9 +339,9 @@ object ShardCoordinator {
* INTERNAL API. Rebalancing process is performed by this actor. * INTERNAL API. Rebalancing process is performed by this actor.
* It sends `BeginHandOff` to all `ShardRegion` actors followed by * It sends `BeginHandOff` to all `ShardRegion` actors followed by
* `HandOff` to the `ShardRegion` responsible for the shard. * `HandOff` to the `ShardRegion` responsible for the shard.
* When the handoff is completed it sends [[RebalanceDone]] to its * When the handoff is completed it sends [[akka.cluster.sharding.RebalanceDone]] to its
* parent `ShardCoordinator`. If the process takes longer than the * parent `ShardCoordinator`. If the process takes longer than the
* `handOffTimeout` it also sends [[RebalanceDone]]. * `handOffTimeout` it also sends [[akka.cluster.sharding.RebalanceDone]].
*/ */
private[akka] class RebalanceWorker(shard: String, from: ActorRef, handOffTimeout: FiniteDuration, private[akka] class RebalanceWorker(shard: String, from: ActorRef, handOffTimeout: FiniteDuration,
regions: Set[ActorRef]) extends Actor { regions: Set[ActorRef]) extends Actor {

View file

@ -18,9 +18,10 @@ import akka.stream.javadsl.Source;
* The model of multipart content for media-types `multipart/\*` (general multipart content), * The model of multipart content for media-types `multipart/\*` (general multipart content),
* `multipart/form-data` and `multipart/byteranges`. * `multipart/form-data` and `multipart/byteranges`.
* *
* The basic modelling classes for these media-types ([[Multipart.General]], [[Multipart.FormData]] and * The basic modelling classes for these media-types ([[akka.http.scaladsl.Multipart.General]], [[Multipart.FormData]] and
* [[Multipart.ByteRanges]], respectively) are stream-based but each have a strict counterpart * [[akka.http.scaladsl.Multipart.ByteRanges]], respectively) are stream-based but each have a strict counterpart
* (namely [[Multipart.General.Strict]], [[Multipart.FormData.Strict]] and [[Multipart.ByteRanges.Strict]]). * (namely [[akka.http.scaladsl.Multipart.General.Strict]], [[akka.http.scaladsl.Multipart.FormData.Strict]] and
* [[akka.http.scaladsl.Multipart.ByteRanges.Strict]]).
*/ */
public interface Multipart { public interface Multipart {

View file

@ -54,7 +54,7 @@ class HttpExt(private val config: Config)(implicit val system: ActorSystem) exte
private[this] final val DefaultPortForProtocol = -1 // any negative value private[this] final val DefaultPortForProtocol = -1 // any negative value
/** /**
* Creates a [[Source]] of [[IncomingConnection]] instances which represents a prospective HTTP server binding * Creates a [[akka.stream.scaladsl.Source]] of [[IncomingConnection]] instances which represents a prospective HTTP server binding
* on the given `endpoint`. * on the given `endpoint`.
* *
* If the given port is 0 the resulting source can be materialized several times. Each materialization will * If the given port is 0 the resulting source can be materialized several times. Each materialization will
@ -666,16 +666,16 @@ object Http extends ExtensionId[HttpExt] with ExtensionIdProvider {
/** /**
* Represents a prospective HTTP server binding. * Represents a prospective HTTP server binding.
* *
* @param localAddress The local address of the endpoint bound by the materialization of the `connections` [[Source]] * @param localAddress The local address of the endpoint bound by the materialization of the `connections` [[akka.stream.scaladsl.Source]]
* *
*/ */
final case class ServerBinding(localAddress: InetSocketAddress)(private val unbindAction: () Future[Unit]) { final case class ServerBinding(localAddress: InetSocketAddress)(private val unbindAction: () Future[Unit]) {
/** /**
* Asynchronously triggers the unbinding of the port that was bound by the materialization of the `connections` * Asynchronously triggers the unbinding of the port that was bound by the materialization of the `connections`
* [[Source]] * [[akka.stream.scaladsl.Source]]
* *
* The produced [[Future]] is fulfilled when the unbinding has been completed. * The produced [[scala.concurrent.Future]] is fulfilled when the unbinding has been completed.
*/ */
def unbind(): Future[Unit] = unbindAction() def unbind(): Future[Unit] = unbindAction()
} }
@ -722,7 +722,7 @@ object Http extends ExtensionId[HttpExt] with ExtensionIdProvider {
/** /**
* Asynchronously triggers the shutdown of the host connection pool. * Asynchronously triggers the shutdown of the host connection pool.
* *
* The produced [[Future]] is fulfilled when the shutdown has been completed. * The produced [[scala.concurrent.Future]] is fulfilled when the shutdown has been completed.
*/ */
def shutdown()(implicit ec: ExecutionContextExecutor): Future[Done] = gatewayFuture.flatMap(_.shutdown()) def shutdown()(implicit ec: ExecutionContextExecutor): Future[Done] = gatewayFuture.flatMap(_.shutdown())
@ -746,7 +746,7 @@ object Http extends ExtensionId[HttpExt] with ExtensionIdProvider {
* TLS configuration for an HTTPS server binding or client connection. * TLS configuration for an HTTPS server binding or client connection.
* For the sslContext please refer to the com.typeasfe.ssl-config library. * For the sslContext please refer to the com.typeasfe.ssl-config library.
* The remaining four parameters configure the initial session that will * The remaining four parameters configure the initial session that will
* be negotiated, see [[NegotiateNewSession]] for details. * be negotiated, see [[akka.stream.TLSProtocol.NegotiateNewSession]] for details.
*/ */
trait DefaultSSLContextCreation { trait DefaultSSLContextCreation {

View file

@ -195,8 +195,8 @@ object HttpEntity {
HttpEntity.Chunked.fromData(contentType, data) HttpEntity.Chunked.fromData(contentType, data)
/** /**
* Returns either the empty entity, if the given file is empty, or a [[Default]] entity * Returns either the empty entity, if the given file is empty, or a [[HttpEntity.Default]] entity
* consisting of a stream of [[ByteString]] instances each containing `chunkSize` bytes * consisting of a stream of [[akka.util.ByteString]] instances each containing `chunkSize` bytes
* (except for the final ByteString, which simply contains the remaining bytes). * (except for the final ByteString, which simply contains the remaining bytes).
* *
* If the given `chunkSize` is -1 the default chunk size is used. * If the given `chunkSize` is -1 the default chunk size is used.

View file

@ -42,13 +42,13 @@ object HttpHeader {
* partial value parsing. In this case the method returns a `ParsingResult.Ok` with the respective header * partial value parsing. In this case the method returns a `ParsingResult.Ok` with the respective header
* instance holding the valid value elements and an [[ErrorInfo]] for each invalid value. * instance holding the valid value elements and an [[ErrorInfo]] for each invalid value.
* c) the value has invalid elements and the header type doesn't support partial value parsing. * c) the value has invalid elements and the header type doesn't support partial value parsing.
* In this case the method returns a `ParsingResult.Ok` with a [[RawHeader]] instance and * In this case the method returns a `ParsingResult.Ok` with a [[akka.http.scaladsl.model.headers.RawHeader]] instance and
* a single [[ErrorInfo]] for the value parsing problem. * a single [[ErrorInfo]] for the value parsing problem.
* *
* 2. The header name does not correspond to a properly modelled header but the header name and the value are both * 2. The header name does not correspond to a properly modelled header but the header name and the value are both
* syntactically legal according to the basic header requirements from the HTTP specification. * syntactically legal according to the basic header requirements from the HTTP specification.
* (http://tools.ietf.org/html/rfc7230#section-3.2) * (http://tools.ietf.org/html/rfc7230#section-3.2)
* In this case the method returns a `ParsingResult.Ok` with a [[RawHeader]] instance and no errors. * In this case the method returns a `ParsingResult.Ok` with a [[akka.http.scaladsl.model.headers.RawHeader]] instance and no errors.
* *
* 3. The header name or value are illegal according to the basic requirements for HTTP headers * 3. The header name or value are illegal according to the basic requirements for HTTP headers
* (http://tools.ietf.org/html/rfc7230#section-3.2). In this case the method returns a `ParsingResult.Error`. * (http://tools.ietf.org/html/rfc7230#section-3.2). In this case the method returns a `ParsingResult.Error`.

View file

@ -155,7 +155,7 @@ final case class HttpRequest(method: HttpMethod = HttpMethods.GET,
* http://tools.ietf.org/html/rfc7230#section-5.5 * http://tools.ietf.org/html/rfc7230#section-5.5
* *
* Throws an [[IllegalUriException]] if the URI is relative and the `headers` don't * Throws an [[IllegalUriException]] if the URI is relative and the `headers` don't
* include a valid [[Host]] header or if URI authority and [[Host]] header don't match. * include a valid [[akka.http.scaladsl.model.headers.Host]] header or if URI authority and [[akka.http.scaladsl.model.headers.Host]] header don't match.
*/ */
def effectiveUri(securedConnection: Boolean, defaultHostHeader: Host = Host.empty): Uri = def effectiveUri(securedConnection: Boolean, defaultHostHeader: Host = Host.empty): Uri =
HttpRequest.effectiveUri(uri, headers, securedConnection, defaultHostHeader) HttpRequest.effectiveUri(uri, headers, securedConnection, defaultHostHeader)

View file

@ -15,7 +15,7 @@ sealed trait Message
/** /**
* Represents a WebSocket text message. A text message can either be a [[TextMessage.Strict]] in which case * Represents a WebSocket text message. A text message can either be a [[TextMessage.Strict]] in which case
* the complete data is already available or it can be [[TextMessage.Streamed]] in which case [[textStream]] * the complete data is already available or it can be [[TextMessage.Streamed]] in which case `textStream`
* will return a Source streaming the data as it comes in. * will return a Source streaming the data as it comes in.
*/ */
sealed trait TextMessage extends Message { sealed trait TextMessage extends Message {
@ -42,7 +42,7 @@ object TextMessage {
/** /**
* Represents a WebSocket binary message. A binary message can either be [[BinaryMessage.Strict]] in which case * Represents a WebSocket binary message. A binary message can either be [[BinaryMessage.Strict]] in which case
* the complete data is already available or it can be [[BinaryMessage.Streamed]] in which case [[dataStream]] * the complete data is already available or it can be [[BinaryMessage.Streamed]] in which case `dataStream`
* will return a Source streaming the data as it comes in. * will return a Source streaming the data as it comes in.
*/ */
//#message-model //#message-model
@ -59,7 +59,7 @@ object BinaryMessage {
Streamed(dataStream) Streamed(dataStream)
/** /**
* A strict [[BinaryMessage]] that contains the complete data as a [[ByteString]]. * A strict [[BinaryMessage]] that contains the complete data as a [[akka.util.ByteString]].
*/ */
final case class Strict(data: ByteString) extends BinaryMessage { final case class Strict(data: ByteString) extends BinaryMessage {
def dataStream: Source[ByteString, _] = Source.single(data) def dataStream: Source[ByteString, _] = Source.single(data)

View file

@ -12,8 +12,8 @@ import scala.concurrent.duration.Duration
import scala.concurrent._ import scala.concurrent._
/** /**
* Provides alternative implementations of the basic transformation operations defined on [[Future]], * Provides alternative implementations of the basic transformation operations defined on [[scala.concurrent.Future]],
* which try to avoid scheduling to an [[ExecutionContext]] if possible, i.e. if the given future * which try to avoid scheduling to an [[scala.concurrent.ExecutionContext]] if possible, i.e. if the given future
* value is already present. * value is already present.
*/ */
class FastFuture[A](val future: Future[A]) extends AnyVal { class FastFuture[A](val future: Future[A]) extends AnyVal {

View file

@ -14,7 +14,7 @@ import scala.concurrent.duration._
import scala.concurrent.Await import scala.concurrent.Await
/** /**
* A RouteTest that uses JUnit assertions. ActorSystem and Materializer are provided as an [[ExternalResource]] * A RouteTest that uses JUnit assertions. ActorSystem and Materializer are provided as an [[org.junit.rules.ExternalResource]]
* and their lifetime is automatically managed. * and their lifetime is automatically managed.
*/ */
abstract class JUnitRouteTestBase extends RouteTest { abstract class JUnitRouteTestBase extends RouteTest {

View file

@ -24,7 +24,7 @@ import akka.http.impl.util._
/** /**
* A base class to create route tests for testing libraries. An implementation needs to provide * A base class to create route tests for testing libraries. An implementation needs to provide
* code to provide and shutdown an [[ActorSystem]], [[Materializer]], and [[ExecutionContextExecutor]]. * code to provide and shutdown an [[akka.actor.ActorSystem]], [[akka.stream.Materializer]], and [[scala.concurrent.ExecutionContextExecutor]].
* Also an implementation should provide instances of [[TestResponse]] to define the assertion * Also an implementation should provide instances of [[TestResponse]] to define the assertion
* facilities of the testing library. * facilities of the testing library.
* *
@ -77,7 +77,7 @@ abstract class RouteTest extends AllDirectives {
} }
/** /**
* Creates a [[TestRoute]] for the main route of an [[HttpApp]]. * Creates a [[TestRoute]] for the main route of an [[akka.http.javadsl.server.HttpApp]].
*/ */
def testAppRoute(app: HttpApp): TestRoute = testRoute(app.createRoute()) def testAppRoute(app: HttpApp): TestRoute = testRoute(app.createRoute())

View file

@ -63,7 +63,7 @@ abstract class TestResponse(_response: HttpResponse, awaitAtMost: FiniteDuration
def entityAsString: String = entity.getData.utf8String def entityAsString: String = entity.getData.utf8String
/** /**
* Returns the [[StatusCode]] of the response. * Returns the [[akka.http.javadsl.model.StatusCode]] of the response.
*/ */
def status: StatusCode = response.status.asJava def status: StatusCode = response.status.asJava
@ -117,7 +117,7 @@ abstract class TestResponse(_response: HttpResponse, awaitAtMost: FiniteDuration
assertEqualsKind(expected, entityBytes, "entity") assertEqualsKind(expected, entityBytes, "entity")
/** /**
* Assert on the response entity to equal the given object after applying an [[Unmarshaller]]. * Assert on the response entity to equal the given object after applying an [[akka.http.javadsl.server.Unmarshaller]].
*/ */
def assertEntityAs[T <: AnyRef](unmarshaller: Unmarshaller[T], expected: T): TestResponse = def assertEntityAs[T <: AnyRef](unmarshaller: Unmarshaller[T], expected: T): TestResponse =
assertEqualsKind(expected, entityAs(unmarshaller), "entity") assertEqualsKind(expected, entityAs(unmarshaller), "entity")

View file

@ -10,7 +10,7 @@ import java.util.concurrent.CompletionStage
/** /**
* A convenience class to derive from to get everything from HttpService and Directives into scope. * A convenience class to derive from to get everything from HttpService and Directives into scope.
* Implement the [[HttpApp.createRoute]] method to provide the Route and then call [[HttpApp.bindRoute]] * Implement the [[createRoute]] method to provide the Route and then call [[bindRoute]]
* to start the server on the specified interface. * to start the server on the specified interface.
*/ */
abstract class HttpApp abstract class HttpApp

View file

@ -5,7 +5,7 @@
package akka.http.javadsl.server package akka.http.javadsl.server
/** /**
* A marker trait for a marshaller that converts a value of type [[T]] to an * A marker trait for a marshaller that converts a value of type `T` to an
* HttpResponse. * HttpResponse.
*/ */
trait Marshaller[T] trait Marshaller[T]

View file

@ -12,9 +12,9 @@ trait RequestVal[T] { outer ⇒
* An accessor for the value given the [[RequestContext]]. * An accessor for the value given the [[RequestContext]].
* *
* Note, that some RequestVals need to be actively specified in the route structure to * Note, that some RequestVals need to be actively specified in the route structure to
* be extracted at a particular point during routing. One example is a [[PathMatcher]] * be extracted at a particular point during routing. One example is a [[akka.http.javadsl.server.values.PathMatcher]]
* that needs to used with a [[directives.PathDirectives]] to specify which part of the * that needs to used with a [[directives.PathDirectives]] to specify which part of the
* path should actually be extracted. Another example is an [[HttpBasicAuthenticator]] * path should actually be extracted. Another example is an [[akka.http.javadsl.server.values.HttpBasicAuthenticator]]
* that needs to be used in the route explicitly to be activated. * that needs to be used in the route explicitly to be activated.
*/ */
def get(ctx: RequestContext): T def get(ctx: RequestContext): T

View file

@ -94,7 +94,7 @@ object RequestVals {
} }
/** /**
* Creates a new [[RequestVal]] given a [[ju.Map]] and a [[RequestVal]] that represents the key. * Creates a new [[RequestVal]] given a [[java.util.Map]] and a [[RequestVal]] that represents the key.
* The new RequestVal represents the existing value as looked up in the map. If the key doesn't * The new RequestVal represents the existing value as looked up in the map. If the key doesn't
* exist the request is rejected. * exist the request is rejected.
*/ */

View file

@ -11,14 +11,14 @@ import akka.http.scaladsl.server
import akka.http.impl.server.RouteStructure._ import akka.http.impl.server.RouteStructure._
/** /**
* Implement this interface to provide a custom mapping from a file name to a [[ContentType]]. * Implement this interface to provide a custom mapping from a file name to a [[akka.http.javadsl.model.ContentType]].
*/ */
trait ContentTypeResolver { trait ContentTypeResolver {
def resolve(fileName: String): ContentType def resolve(fileName: String): ContentType
} }
/** /**
* A resolver that assumes the given constant [[ContentType]] for all files. * A resolver that assumes the given constant [[akka.http.javadsl.model.ContentType]] for all files.
*/ */
case class StaticContentTypeResolver(contentType: ContentType) extends ContentTypeResolver { case class StaticContentTypeResolver(contentType: ContentType) extends ContentTypeResolver {
def resolve(fileName: String): ContentType = contentType def resolve(fileName: String): ContentType = contentType
@ -32,13 +32,13 @@ case class StaticContentTypeResolver(contentType: ContentType) extends ContentTy
*/ */
trait FileAndResourceRoute extends Route { trait FileAndResourceRoute extends Route {
/** /**
* Returns a variant of this route that responds with the given constant [[ContentType]]. * Returns a variant of this route that responds with the given constant [[akka.http.javadsl.model.ContentType]].
*/ */
def withContentType(contentType: ContentType): Route def withContentType(contentType: ContentType): Route
/** /**
* Returns a variant of this route that uses the specified [[ContentTypeResolver]] to determine * Returns a variant of this route that uses the specified [[ContentTypeResolver]] to determine
* which [[ContentType]] to respond with by file name. * which [[akka.http.javadsl.model.ContentType]] to respond with by file name.
*/ */
def resolveContentTypeWith(resolver: ContentTypeResolver): Route def resolveContentTypeWith(resolver: ContentTypeResolver): Route
} }
@ -115,12 +115,12 @@ abstract class FileAndResourceDirectives extends ExecutionDirectives {
def getFromDirectory(directoryPath: String): FileAndResourceRoute = getFromDirectory(new File(directoryPath)) def getFromDirectory(directoryPath: String): FileAndResourceRoute = getFromDirectory(new File(directoryPath))
/** /**
* Same as [[getFromDirectory]] but generates a listing of files if the path is a directory. * Same as [[#getFromDirectory]] but generates a listing of files if the path is a directory.
*/ */
def getFromBrowseableDirectory(directory: File): FileAndResourceRoute = FileAndResourceRoute(GetFromDirectory(directory, browseable = true, _)) def getFromBrowseableDirectory(directory: File): FileAndResourceRoute = FileAndResourceRoute(GetFromDirectory(directory, browseable = true, _))
/** /**
* Same as [[getFromDirectory]] but generates a listing of files if the path is a directory. * Same as [[#getFromDirectory]] but generates a listing of files if the path is a directory.
*/ */
def getFromBrowseableDirectory(directoryPath: String): FileAndResourceRoute = FileAndResourceRoute(GetFromDirectory(new File(directoryPath), browseable = true, _)) def getFromBrowseableDirectory(directoryPath: String): FileAndResourceRoute = FileAndResourceRoute(GetFromDirectory(new File(directoryPath), browseable = true, _))

View file

@ -19,7 +19,7 @@ abstract class PathDirectives extends MiscDirectives {
* The matcher has to match the remaining path completely. * The matcher has to match the remaining path completely.
* If matched the value extracted by the PathMatchers is extracted on the directive level. * If matched the value extracted by the PathMatchers is extracted on the directive level.
* *
* Each of Each of the arguments s must either be an instance of [[PathMatcher]] or a constant String * Each of Each of the arguments s must either be an instance of [[akka.http.javadsl.server.values.PathMatcher]] or a constant String
* that will be automatically converted using `PathMatcher.segment`. * that will be automatically converted using `PathMatcher.segment`.
*/ */
@varargs @varargs
@ -31,7 +31,7 @@ abstract class PathDirectives extends MiscDirectives {
* The matcher has to match a prefix of the remaining path. * The matcher has to match a prefix of the remaining path.
* If matched the value extracted by the PathMatcher is extracted on the directive level. * If matched the value extracted by the PathMatcher is extracted on the directive level.
* *
* Each of the arguments must either be an instance of [[PathMatcher]] or a constant String * Each of the arguments must either be an instance of [[akka.http.javadsl.server.values.PathMatcher]] or a constant String
* that will be automatically converted using `PathMatcher.segment`. * that will be automatically converted using `PathMatcher.segment`.
*/ */
@varargs @varargs
@ -39,10 +39,10 @@ abstract class PathDirectives extends MiscDirectives {
RawPathPrefixForMatchers(joinWithSlash(convertMatchers(matchers))) RawPathPrefixForMatchers(joinWithSlash(convertMatchers(matchers)))
/** /**
* Checks whether the unmatchedPath of the [[RequestContext]] has a prefix matched by the * Checks whether the unmatchedPath of the [[akka.http.javadsl.server.RequestContext]] has a prefix matched by the
* given PathMatcher. In analogy to the `pathPrefix` directive a leading slash is implied. * given PathMatcher. In analogy to the `pathPrefix` directive a leading slash is implied.
* *
* Each of the arguments must either be an instance of [[PathMatcher]] or a constant String * Each of the arguments must either be an instance of [[akka.http.javadsl.server.values.PathMatcher]] or a constant String
* that will be automatically converted using `PathMatcher.segment`. * that will be automatically converted using `PathMatcher.segment`.
*/ */
@varargs @varargs
@ -51,11 +51,11 @@ abstract class PathDirectives extends MiscDirectives {
/** /**
* Applies the given matcher directly to a prefix of the unmatched path of the * Applies the given matcher directly to a prefix of the unmatched path of the
* [[RequestContext]] (i.e. without implicitly consuming a leading slash). * [[akka.http.javadsl.server.RequestContext]] (i.e. without implicitly consuming a leading slash).
* The matcher has to match a prefix of the remaining path. * The matcher has to match a prefix of the remaining path.
* If matched the value extracted by the PathMatcher is extracted on the directive level. * If matched the value extracted by the PathMatcher is extracted on the directive level.
* *
* Each of the arguments must either be an instance of [[PathMatcher]] or a constant String * Each of the arguments must either be an instance of [[akka.http.javadsl.server.values.PathMatcher]] or a constant String
* that will be automatically converted using `PathMatcher.segment`. * that will be automatically converted using `PathMatcher.segment`.
*/ */
@varargs @varargs
@ -63,11 +63,11 @@ abstract class PathDirectives extends MiscDirectives {
RawPathPrefixForMatchers(convertMatchers(matchers)) RawPathPrefixForMatchers(convertMatchers(matchers))
/** /**
* Checks whether the unmatchedPath of the [[RequestContext]] has a prefix matched by the * Checks whether the unmatchedPath of the [[akka.http.javadsl.server.RequestContext]] has a prefix matched by the
* given PathMatcher. However, as opposed to the `pathPrefix` directive the matched path is not * given PathMatcher. However, as opposed to the `pathPrefix` directive the matched path is not
* actually "consumed". * actually "consumed".
* *
* Each of the arguments must either be an instance of [[PathMatcher]] or a constant String * Each of the arguments must either be an instance of [[akka.http.javadsl.server.values.PathMatcher]] or a constant String
* that will be automatically converted using `PathMatcher.segment`. * that will be automatically converted using `PathMatcher.segment`.
*/ */
@varargs @varargs
@ -75,12 +75,12 @@ abstract class PathDirectives extends MiscDirectives {
RawPathPrefixTestForMatchers(convertMatchers(matchers)) RawPathPrefixTestForMatchers(convertMatchers(matchers))
/** /**
* Applies the given PathMatchers to a suffix of the remaining unmatchedPath of the [[RequestContext]]. * Applies the given PathMatchers to a suffix of the remaining unmatchedPath of the [[akka.http.javadsl.server.RequestContext]].
* If matched the value extracted by the PathMatchers is extracted and the matched parts of the path are consumed. * If matched the value extracted by the PathMatchers is extracted and the matched parts of the path are consumed.
* Note that, for efficiency reasons, the given PathMatchers must match the desired suffix in reversed-segment * Note that, for efficiency reasons, the given PathMatchers must match the desired suffix in reversed-segment
* order, i.e. `pathSuffix("baz" / "bar")` would match `/foo/bar/baz`! * order, i.e. `pathSuffix("baz" / "bar")` would match `/foo/bar/baz`!
* *
* Each of the arguments must either be an instance of [[PathMatcher]] or a constant String * Each of the arguments must either be an instance of [[akka.http.javadsl.server.values.PathMatcher]] or a constant String
* that will be automatically converted using `PathMatcher.segment`. * that will be automatically converted using `PathMatcher.segment`.
*/ */
@varargs @varargs
@ -88,13 +88,13 @@ abstract class PathDirectives extends MiscDirectives {
Directives.custom(RouteStructure.PathSuffix(convertMatchers(matchers))) Directives.custom(RouteStructure.PathSuffix(convertMatchers(matchers)))
/** /**
* Checks whether the unmatchedPath of the [[RequestContext]] has a suffix matched by the * Checks whether the unmatchedPath of the [[akka.http.javadsl.server.RequestContext]] has a suffix matched by the
* given PathMatcher. However, as opposed to the pathSuffix directive the matched path is not * given PathMatcher. However, as opposed to the pathSuffix directive the matched path is not
* actually "consumed". * actually "consumed".
* Note that, for efficiency reasons, the given PathMatcher must match the desired suffix in reversed-segment * Note that, for efficiency reasons, the given PathMatcher must match the desired suffix in reversed-segment
* order, i.e. `pathSuffixTest("baz" / "bar")` would match `/foo/bar/baz`! * order, i.e. `pathSuffixTest("baz" / "bar")` would match `/foo/bar/baz`!
* *
* Each of the arguments must either be an instance of [[PathMatcher]] or a constant String * Each of the arguments must either be an instance of [[akka.http.javadsl.server.values.PathMatcher]] or a constant String
* that will be automatically converted using `PathMatcher.segment`. * that will be automatically converted using `PathMatcher.segment`.
*/ */
@varargs @varargs
@ -102,7 +102,7 @@ abstract class PathDirectives extends MiscDirectives {
Directives.custom(RouteStructure.PathSuffixTest(convertMatchers(matchers))) Directives.custom(RouteStructure.PathSuffixTest(convertMatchers(matchers)))
/** /**
* Rejects the request if the unmatchedPath of the [[RequestContext]] is non-empty, * Rejects the request if the unmatchedPath of the [[akka.http.javadsl.server.RequestContext]] is non-empty,
* or said differently: only passes on the request to its inner route if the request path * or said differently: only passes on the request to its inner route if the request path
* has been matched completely. * has been matched completely.
*/ */
@ -114,7 +114,7 @@ abstract class PathDirectives extends MiscDirectives {
* *
* Note that trailing slash and non-trailing slash URLs are '''not''' the same, although they often serve * Note that trailing slash and non-trailing slash URLs are '''not''' the same, although they often serve
* the same content. It is recommended to serve only one URL version and make the other redirect to it using * the same content. It is recommended to serve only one URL version and make the other redirect to it using
* [[redirectToTrailingSlashIfMissing]] or [[redirectToNoTrailingSlashIfPresent]] directive. * [[#redirectToTrailingSlashIfMissing]] or [[#redirectToNoTrailingSlashIfPresent]] directive.
* *
* For example: * For example:
* {{{ * {{{
@ -147,7 +147,7 @@ abstract class PathDirectives extends MiscDirectives {
/** /**
* If the request path doesn't end with a slash, redirect to the same uri with trailing slash in the path. * If the request path doesn't end with a slash, redirect to the same uri with trailing slash in the path.
* *
* '''Caveat''': [[path]] without trailing slash and [[pathEnd]] directives will not match inside of this directive. * '''Caveat''': [[#path]] without trailing slash and [[#pathEnd]] directives will not match inside of this directive.
*/ */
@varargs @varargs
def redirectToTrailingSlashIfMissing(redirectionStatusCode: StatusCode, innerRoute: Route, moreInnerRoutes: Route*): Route = def redirectToTrailingSlashIfMissing(redirectionStatusCode: StatusCode, innerRoute: Route, moreInnerRoutes: Route*): Route =
@ -156,7 +156,7 @@ abstract class PathDirectives extends MiscDirectives {
/** /**
* If the request path ends with a slash, redirect to the same uri without trailing slash in the path. * If the request path ends with a slash, redirect to the same uri without trailing slash in the path.
* *
* '''Caveat''': [[pathSingleSlash]] directive will not match inside of this directive. * '''Caveat''': [[#pathSingleSlash]] directive will not match inside of this directive.
*/ */
@varargs @varargs
def redirectToNoTrailingSlashIfPresent(redirectionStatusCode: StatusCode, innerRoute: Route, moreInnerRoutes: Route*): Route = def redirectToNoTrailingSlashIfPresent(redirectionStatusCode: StatusCode, innerRoute: Route, moreInnerRoutes: Route*): Route =

View file

@ -16,13 +16,13 @@ import FastFuture._
/** /**
* Read-only abstraction on top of `application/x-www-form-urlencoded` and multipart form data, * Read-only abstraction on top of `application/x-www-form-urlencoded` and multipart form data,
* allowing joint unmarshalling access to either kind, **if** you supply both, a [[FromStringUnmarshaller]] * allowing joint unmarshalling access to either kind, **if** you supply both, a [[akka.http.scaladsl.unmarshalling.FromStringUnmarshaller]]
* as well as a [[FromEntityUnmarshaller]] for the target type `T`. * as well as a [[akka.http.scaladsl.unmarshalling.FromEntityUnmarshaller]] for the target type `T`.
* Note: In order to allow for random access to the field values streamed multipart form data are strictified! * Note: In order to allow for random access to the field values streamed multipart form data are strictified!
* Don't use this abstraction on potentially unbounded forms (e.g. large file uploads). * Don't use this abstraction on potentially unbounded forms (e.g. large file uploads).
* *
* If you only need to consume one type of form (`application/x-www-form-urlencoded` *or* multipart) then * If you only need to consume one type of form (`application/x-www-form-urlencoded` *or* multipart) then
* simply unmarshal directly to the respective form abstraction ([[FormData]] or [[Multipart.FormData]]) * simply unmarshal directly to the respective form abstraction ([[akka.http.scaladsl.model.FormData]] or [[akka.http.scaladsl.model.Multipart.FormData]])
* rather than going through [[StrictForm]]. * rather than going through [[StrictForm]].
* *
* Simple usage example: * Simple usage example:

View file

@ -31,7 +31,7 @@ trait MayVerb {
* Block of tests which MAY pass, and if not should be ignored. * Block of tests which MAY pass, and if not should be ignored.
* Such as rules which may be optionally implemented by Journals. * Such as rules which may be optionally implemented by Journals.
* *
* MUST be used in conjunction with [[optional]] to provide explanation as to why it may be ok to fail this spec. * MUST be used in conjunction with [[MayVerb#optional]] to provide explanation as to why it may be ok to fail this spec.
* *
* The word `MAY` is to be understood as defined in RFC 2119 * The word `MAY` is to be understood as defined in RFC 2119
* *

View file

@ -242,7 +242,7 @@ trait AtLeastOnceDeliveryLike extends Eventsourced {
* later if no matching `confirmDelivery` was performed. * later if no matching `confirmDelivery` was performed.
* *
* This method will throw [[AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException]] * This method will throw [[AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException]]
* if [[numberOfUnconfirmed]] is greater than or equal to [[#maxUnconfirmedMessages]]. * if [[#numberOfUnconfirmed]] is greater than or equal to [[#maxUnconfirmedMessages]].
*/ */
def deliver(destination: ActorSelection)(deliveryIdToMessage: Long Any): Unit = { def deliver(destination: ActorSelection)(deliveryIdToMessage: Long Any): Unit = {
val isWildcardSelection = destination.pathString.contains("*") val isWildcardSelection = destination.pathString.contains("*")
@ -384,7 +384,7 @@ abstract class UntypedPersistentActorWithAtLeastOnceDelivery extends UntypedPers
* later if no matching `confirmDelivery` was performed. * later if no matching `confirmDelivery` was performed.
* *
* This method will throw [[AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException]] * This method will throw [[AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException]]
* if [[numberOfUnconfirmed]] is greater than or equal to [[#maxUnconfirmedMessages]]. * if [[#numberOfUnconfirmed]] is greater than or equal to [[#maxUnconfirmedMessages]].
*/ */
def deliver(destination: ActorPath, deliveryIdToMessage: akka.japi.Function[java.lang.Long, Object]): Unit = def deliver(destination: ActorPath, deliveryIdToMessage: akka.japi.Function[java.lang.Long, Object]): Unit =
super.deliver(destination)(id deliveryIdToMessage.apply(id)) super.deliver(destination)(id deliveryIdToMessage.apply(id))
@ -407,7 +407,7 @@ abstract class UntypedPersistentActorWithAtLeastOnceDelivery extends UntypedPers
* later if no matching `confirmDelivery` was performed. * later if no matching `confirmDelivery` was performed.
* *
* This method will throw [[AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException]] * This method will throw [[AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException]]
* if [[numberOfUnconfirmed]] is greater than or equal to [[#maxUnconfirmedMessages]]. * if [[#numberOfUnconfirmed]] is greater than or equal to [[#maxUnconfirmedMessages]].
*/ */
def deliver(destination: ActorSelection, deliveryIdToMessage: akka.japi.Function[java.lang.Long, Object]): Unit = def deliver(destination: ActorSelection, deliveryIdToMessage: akka.japi.Function[java.lang.Long, Object]): Unit =
super.deliver(destination)(id deliveryIdToMessage.apply(id)) super.deliver(destination)(id deliveryIdToMessage.apply(id))
@ -442,7 +442,7 @@ abstract class AbstractPersistentActorWithAtLeastOnceDelivery extends AbstractPe
* later if no matching `confirmDelivery` was performed. * later if no matching `confirmDelivery` was performed.
* *
* This method will throw [[AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException]] * This method will throw [[AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException]]
* if [[numberOfUnconfirmed]] is greater than or equal to [[#maxUnconfirmedMessages]]. * if [[#numberOfUnconfirmed]] is greater than or equal to [[#maxUnconfirmedMessages]].
*/ */
def deliver(destination: ActorPath, deliveryIdToMessage: akka.japi.Function[java.lang.Long, Object]): Unit = def deliver(destination: ActorPath, deliveryIdToMessage: akka.japi.Function[java.lang.Long, Object]): Unit =
super.deliver(destination)(id deliveryIdToMessage.apply(id)) super.deliver(destination)(id deliveryIdToMessage.apply(id))
@ -465,7 +465,7 @@ abstract class AbstractPersistentActorWithAtLeastOnceDelivery extends AbstractPe
* later if no matching `confirmDelivery` was performed. * later if no matching `confirmDelivery` was performed.
* *
* This method will throw [[AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException]] * This method will throw [[AtLeastOnceDelivery.MaxUnconfirmedMessagesExceededException]]
* if [[numberOfUnconfirmed]] is greater than or equal to [[#maxUnconfirmedMessages]]. * if [[#numberOfUnconfirmed]] is greater than or equal to [[#maxUnconfirmedMessages]].
*/ */
def deliver(destination: ActorSelection, deliveryIdToMessage: akka.japi.Function[java.lang.Long, Object]): Unit = def deliver(destination: ActorSelection, deliveryIdToMessage: akka.japi.Function[java.lang.Long, Object]): Unit =
super.deliver(destination)(id deliveryIdToMessage.apply(id)) super.deliver(destination)(id deliveryIdToMessage.apply(id))

View file

@ -341,7 +341,7 @@ private[persistence] trait Eventsourced extends Snapshotter with PersistenceStas
* Unlike `persist` the persistent actor will continue to receive incoming commands between the * Unlike `persist` the persistent actor will continue to receive incoming commands between the
* call to `persist` and executing it's `handler`. This asynchronous, non-stashing, version of * call to `persist` and executing it's `handler`. This asynchronous, non-stashing, version of
* of persist should be used when you favor throughput over the "command-2 only processed after * of persist should be used when you favor throughput over the "command-2 only processed after
* command-1 effects' have been applied" guarantee, which is provided by the plain [[persist]] method. * command-1 effects' have been applied" guarantee, which is provided by the plain `persist` method.
* *
* An event `handler` may close over persistent actor state and modify it. The `sender` of a persisted * An event `handler` may close over persistent actor state and modify it. The `sender` of a persisted
* event is the sender of the corresponding command. This means that one can reply to a command * event is the sender of the corresponding command. This means that one can reply to a command

View file

@ -105,7 +105,7 @@ object Recovery {
sealed trait StashOverflowStrategy sealed trait StashOverflowStrategy
/** /**
* Discard the message to [[DeadLetter]]. * Discard the message to [[akka.actor.DeadLetter]].
*/ */
case object DiscardToDeadLetterStrategy extends StashOverflowStrategy { case object DiscardToDeadLetterStrategy extends StashOverflowStrategy {
/** /**
@ -115,7 +115,7 @@ case object DiscardToDeadLetterStrategy extends StashOverflowStrategy {
} }
/** /**
* Throw [[StashOverflowException]], hence the persistent actor will starting recovery * Throw [[akka.actor.StashOverflowException]], hence the persistent actor will starting recovery
* if guarded by default supervisor strategy. * if guarded by default supervisor strategy.
* Be carefully if used together with persist/persistAll or has many messages needed * Be carefully if used together with persist/persistAll or has many messages needed
* to replay. * to replay.

View file

@ -65,7 +65,7 @@ private[akka] object PersistentView {
* Implementation classes refer to a persistent actors' message stream by implementing `persistenceId` * Implementation classes refer to a persistent actors' message stream by implementing `persistenceId`
* with the corresponding (shared) identifier value. * with the corresponding (shared) identifier value.
* *
* Views can also store snapshots of internal state by calling [[autoUpdate]]. The snapshots of a view * Views can also store snapshots of internal state by calling [[PersistentView#autoUpdate]]. The snapshots of a view
* are independent of those of the referenced persistent actor. During recovery, a saved snapshot is offered * are independent of those of the referenced persistent actor. During recovery, a saved snapshot is offered
* to the view with a [[SnapshotOffer]] message, followed by replayed messages, if any, that are younger * to the view with a [[SnapshotOffer]] message, followed by replayed messages, if any, that are younger
* than the snapshot. Default is to offer the latest saved snapshot. * than the snapshot. Default is to offer the latest saved snapshot.
@ -76,8 +76,8 @@ private[akka] object PersistentView {
* `akka.persistence.view.auto-update-interval` configuration key. Applications may trigger additional * `akka.persistence.view.auto-update-interval` configuration key. Applications may trigger additional
* view updates by sending the view [[Update]] requests. See also methods * view updates by sending the view [[Update]] requests. See also methods
* *
* - [[autoUpdate]] for turning automated updates on or off * - [[PersistentView#autoUpdate]] for turning automated updates on or off
* - [[autoUpdateReplayMax]] for limiting the number of replayed messages per view update cycle * - [[PersistentView#autoUpdateReplayMax]] for limiting the number of replayed messages per view update cycle
* *
*/ */
@deprecated("use Persistence Query instead", "2.4") @deprecated("use Persistence Query instead", "2.4")

View file

@ -23,7 +23,7 @@ import akka.util.BoxedType
* uninstall it. * uninstall it.
* *
* You should always prefer the filter methods in the package object * You should always prefer the filter methods in the package object
* (see [[akka.testkit]] `filterEvents` and `filterException`) or on the * (see `akka.testkit` `filterEvents` and `filterException`) or on the
* EventFilter implementations. * EventFilter implementations.
*/ */
sealed trait TestEvent sealed trait TestEvent
@ -34,7 +34,7 @@ sealed trait TestEvent
* uninstall it. * uninstall it.
* *
* You should always prefer the filter methods in the package object * You should always prefer the filter methods in the package object
* (see [[akka.testkit]] `filterEvents` and `filterException`) or on the * (see `akka.testkit` `filterEvents` and `filterException`) or on the
* EventFilter implementations. * EventFilter implementations.
*/ */
object TestEvent { object TestEvent {
@ -141,7 +141,7 @@ abstract class EventFilter(occurrences: Int) {
* that you can keep your test runs console output clean and do not miss real * that you can keep your test runs console output clean and do not miss real
* error messages. * error messages.
* *
* '''Also have a look at the [[akka.testkit]] package objects `filterEvents` and * '''Also have a look at the `akka.testkit` package objects `filterEvents` and
* `filterException` methods.''' * `filterException` methods.'''
* *
* The source filters do accept `Class[_]` arguments, matching any * The source filters do accept `Class[_]` arguments, matching any

View file

@ -185,7 +185,7 @@ object ScalaDSL {
/** /**
* This type of Behavior is created from a partial function from the declared * This type of Behavior is created from a partial function from the declared
* message type to the next behavior, flagging all unmatched messages as * message type to the next behavior, flagging all unmatched messages as
* [[Unhandled]]. All system signals are * [[ScalaDSL.Unhandled]]. All system signals are
* ignored by this behavior, which implies that a failure of a child actor * ignored by this behavior, which implies that a failure of a child actor
* will be escalated unconditionally. * will be escalated unconditionally.
* *