services.rabbitmq

RabbitmqExtractionBusService

class RabbitmqExtractionBusService extends ExtractionBusService

Rabbitmq service.

Annotations
@Singleton()
Linear Supertypes
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. RabbitmqExtractionBusService
  2. ExtractionBusService
  3. AnyRef
  4. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Instance Constructors

  1. new RabbitmqExtractionBusService(files: FileService, spacesService: SpaceService, extractorsService: ExtractorService, datasetService: DatasetService, userService: UserService)

    Annotations
    @Inject()

Value Members

  1. final def !=(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

    Definition Classes
    AnyRef → Any
  4. final def ==(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  5. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  6. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  7. var bindings: List[Binding]

  8. def cancelPendingSubmission(id: UUID, queueName: String, msg_id: UUID): Unit

  9. val cancellationDownloadQueueName: String

  10. var cancellationQueue: Option[ActorRef]

  11. var channel: Option[Channel]

  12. def clone(): AnyRef

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  13. def close(): Unit

    Close connection to broker.

    Close connection to broker. *

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  14. def connect(): Boolean

  15. var connection: Option[Connection]

  16. final def eq(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  17. def equals(arg0: Any): Boolean

    Definition Classes
    AnyRef → Any
  18. var event_filter: Option[ActorRef]

  19. var exchange: String

  20. var extractQueue: Option[ActorRef]

  21. var extractorsHeartbeats: Option[ActorRef]

  22. var factory: Option[ConnectionFactory]

  23. def fileAddedToDataset(file: File, dataset: Dataset, host: String, requestAPIKey: Option[String]): Unit

    Send message when a file is added to a dataset.

    Send message when a file is added to a dataset. Use both old method using topic queues and new method using work queues and extractors registration in Clowder.

    file

    the file that was added to the dataset

    dataset

    the dataset it was added to

    host

    the Clowder host URL for sharing extractors across instances

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  24. def fileCreated(file: TempFile, host: String, requestAPIKey: Option[String]): Unit

    Send message when a new file is uploaded to the system.

    Send message when a new file is uploaded to the system. This is the same as the method above but it supports TempFile instead of File. This is currently only used for multimedia queries.

    file

    the file that was just uploaded

    host

    the Clowder host URL for sharing extractors across instances

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  25. def fileCreated(file: File, dataset: Option[Dataset], host: String, requestAPIKey: Option[String]): Unit

    Publish to the proper queues when a new file is uploaded to the system.

    Publish to the proper queues when a new file is uploaded to the system.

    file

    the file that was just uploaded

    dataset

    the dataset the file belongs to

    host

    the Clowder host URL for sharing extractors across instances

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  26. def fileRemovedFromDataset(file: File, dataset: Dataset, host: String, requestAPIKey: Option[String]): Unit

    Send message when file is removed from a dataset and deleted.

    Send message when file is removed from a dataset and deleted.

    file
    dataset
    host

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  27. def fileSetAddedToDataset(dataset: Dataset, filelist: List[File], host: String, requestAPIKey: Option[String]): Unit

    Send message when a group of files is added to a dataset via UI.

    Send message when a group of files is added to a dataset via UI. Use both old method using topic queues and new method using work queues and extractors registration in Clowder.

    dataset

    the dataset it was added to

    filelist

    the list of files that were added to the dataset

    host

    the Clowder host URL for sharing extractors across instances

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  28. def finalize(): Unit

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  29. def getApiKey(requestAPIKey: Option[String], user: Option[User]): String

    Return the API key to use in the submission.

    Return the API key to use in the submission. If the one in the key is not set in the request then get the default extraction key for the user. If the user is not defined default to the global key. for the user

    requestAPIKey

    the API key from the request

    user

    the user from the request

    returns

    the API key to use

  30. def getBindings: Future[Response]

    Get the binding lists (lists of routing keys) from the rabbitmq broker

    Get the binding lists (lists of routing keys) from the rabbitmq broker

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  31. def getChannelInfo(cid: String): Future[Response]

    Get Channel information from rabbitmq broker for given channel id 'cid'

  32. def getChannelsList: Future[Response]

    Get Channel list from rabbitmq broker

    Get Channel list from rabbitmq broker

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  33. final def getClass(): Class[_]

    Definition Classes
    AnyRef → Any
  34. def getEmailNotificationEmailList(requestAPIKey: Option[String]): List[String]

    a helper function to get user email address from user's request api key.

    a helper function to get user email address from user's request api key.

    requestAPIKey

    user request apikey

    returns

    a list of email address

  35. def getExchanges: Future[Response]

    Get the exchange list for a given host

    Get the exchange list for a given host

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  36. def getQueueBindings(qname: String): Future[Response]

    Get queue bindings for a given host and queue from rabbitmq broker

    Get queue bindings for a given host and queue from rabbitmq broker

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  37. def getQueueDetails(qname: String): Future[Response]

    Get queue details for a given queue

    Get queue details for a given queue

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  38. def getQueuesNamesForAnExchange(exchange: String): Future[Response]

    get list of queues attached to an exchange

    get list of queues attached to an exchange

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  39. def getRestEndPoint(path: String): Future[Response]

  40. var globalAPIKey: String

  41. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  42. final def isInstanceOf[T0]: Boolean

    Definition Classes
    Any
  43. def metadataAddedToResource(metadataId: UUID, resourceRef: ResourceRef, extraInfo: Map[String, Any], host: String, requestAPIKey: Option[String], user: Option[User]): Unit

    Metadata added to a resource (file or dataset).

    Metadata added to a resource (file or dataset).

    resourceRef
    extraInfo
    host

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  44. def metadataRemovedFromResource(metadataId: UUID, resourceRef: ResourceRef, host: String, requestAPIKey: Option[String], user: Option[User]): Unit

    Metadata removed from a resource (file or dataset).

    Metadata removed from a resource (file or dataset).

    resourceRef
    host

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  45. var mgmtPort: String

  46. def multimediaQuery(tempFileId: UUID, contentType: String, length: String, host: String, requestAPIKey: Option[String]): Unit

    File upladed for multimedia query.

    File upladed for multimedia query. Not a common used feature.

    tempFileId
    contentType
    length
    host

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  47. final def ne(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  48. final def notify(): Unit

    Definition Classes
    AnyRef
  49. final def notifyAll(): Unit

    Definition Classes
    AnyRef
  50. def onStart(): Unit

    On start connect to broker.

    On start connect to broker.

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  51. def onStop(): Unit

    On stop clean up connection.

    On stop clean up connection.

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  52. var password: String

  53. def postSubmissionEvent(file_id: UUID, extractor_id: String): UUID

    Post the event of SUBMITTED

    Post the event of SUBMITTED

    file_id

    the UUID of file

    extractor_id

    the extractor queue name to be submitted

  54. var rabbitmquri: String

  55. var restURL: Option[String]

  56. def resubmitPendingRequests(cancellationQueueConsumer: QueueingConsumer, channel: Channel, cancellationSearchTimeout: Long): Unit

    loop through the queue and dispatch the message via the routing key.

    loop through the queue and dispatch the message via the routing key.

    cancellationQueueConsumer

    the queue consumer to download the requests from the cancellation downloaded queue

    channel

    the channel connecting to the rabbitmq

    cancellationSearchTimeout

    the timeout of downloading the requests from the rabbitmq

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  57. def submitDatasetManually(host: String, queue: String, extraInfo: Map[String, Any], datasetId: UUID, newFlags: String, requestAPIKey: Option[String], user: Option[User]): Boolean

    An existing dataset was manually submitted to the extraction bus by a user.

    An existing dataset was manually submitted to the extraction bus by a user.

    host
    queue
    extraInfo
    datasetId
    newFlags

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  58. def submitFileManually(originalId: UUID, file: File, host: String, queue: String, extraInfo: Map[String, Any], datasetId: UUID, newFlags: String, requestAPIKey: Option[String], user: Option[User]): Boolean

    An existing file was manually submitted to the extraction bus by a user.

    An existing file was manually submitted to the extraction bus by a user.

    originalId
    file
    host
    queue
    extraInfo
    datasetId
    newFlags

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  59. def submitSectionPreviewManually(preview: Preview, sectionId: UUID, host: String, requestAPIKey: Option[String]): Unit

    Preview creted for section.

    Preview creted for section.

    preview
    sectionId
    host

    Definition Classes
    RabbitmqExtractionBusServiceExtractionBusService
  60. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  61. def toString(): String

    Definition Classes
    AnyRef → Any
  62. var username: String

  63. var vhost: String

  64. final def wait(): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  65. final def wait(arg0: Long, arg1: Int): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  66. final def wait(arg0: Long): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from ExtractionBusService

Inherited from AnyRef

Inherited from Any

Ungrouped