org.apache.activemq.apollo.broker.store

DelayingStoreSupport

trait DelayingStoreSupport extends Store with BaseService

Support class for implementing Stores which delay doing updates so that it can support potentially be canceling the update due to subsequent operation.

Linear Supertypes
BaseService, Dispatched, Store, ServiceTrait, Service, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. Hide All
  2. Show all
  1. DelayingStoreSupport
  2. BaseService
  3. Dispatched
  4. Store
  5. ServiceTrait
  6. Service
  7. AnyRef
  8. Any
Visibility
  1. Public
  2. All

Type Members

  1. class DelayableUOW extends BaseRetained with StoreUOW

Abstract Value Members

  1. def _start (on_completed: Runnable): Unit

    Attributes
    protected abstract
    Definition Classes
    BaseService
  2. def _stop (on_completed: Runnable): Unit

    Attributes
    protected abstract
    Definition Classes
    BaseService
  3. def add_queue (record: QueueRecord)(callback: (Boolean) ⇒ Unit): Unit

    Adds a queue.

    Adds a queue.

    This method auto generates and assigns the key field of the queue record and returns true if it succeeded.

    Attributes
    abstract
    Definition Classes
    Store
  4. def export_pb (streams: StreamManager[OutputStream]): org.apache.activemq.apollo.util.Result[org.apache.activemq.apollo.util.Zilch,String] @scala.util.continuations.cpsParam[Unit,Unit]

    Exports the contents of the store to the provided streams.

    Exports the contents of the store to the provided streams. Each stream should contain a list of framed protobuf objects with the corresponding object types.

    Attributes
    abstract
    Definition Classes
    Store
  5. def flush_delay : Long

    Attributes
    protected abstract
  6. def get (key: Buffer)(callback: (Option[Buffer]) ⇒ Unit): Unit

    Gets a value of a previously stored map entry.

    Gets a value of a previously stored map entry.

    Attributes
    abstract
    Definition Classes
    Store
  7. def get_last_queue_key (callback: (Option[Long]) ⇒ Unit): Unit

    Ges the last queue key identifier stored.

    Ges the last queue key identifier stored.

    Attributes
    abstract
    Definition Classes
    Store
  8. def get_next_msg_key : Long

    Attributes
    protected abstract
  9. def get_queue (queueKey: Long)(callback: (Option[QueueRecord]) ⇒ Unit): Unit

    Loads the queue information for a given queue key.

    Loads the queue information for a given queue key.

    Attributes
    abstract
    Definition Classes
    Store
  10. def get_store_status (callback: (StoreStatusDTO) ⇒ Unit): Unit

    Attributes
    abstract
    Definition Classes
    Store
  11. def import_pb (streams: StreamManager[InputStream]): org.apache.activemq.apollo.util.Result[org.apache.activemq.apollo.util.Zilch,String] @scala.util.continuations.cpsParam[Unit,Unit]

    Imports a previously exported set of streams.

    Imports a previously exported set of streams. This deletes any previous data in the store.

    Attributes
    abstract
    Definition Classes
    Store
  12. def list_queue_entries (queueKey: Long, firstSeq: Long, lastSeq: Long)(callback: (Seq[QueueEntryRecord]) ⇒ Unit): Unit

    Loads all the queue entry records for the given queue id between the first and last provided queue sequences (inclusive).

    Loads all the queue entry records for the given queue id between the first and last provided queue sequences (inclusive).

    Attributes
    abstract
    Definition Classes
    Store
  13. def list_queue_entry_ranges (queueKey: Long, limit: Int)(callback: (Seq[QueueEntryRange]) ⇒ Unit): Unit

    Groups all the entries in the specified queue into ranges containing up limit entries big and returns those ranges.

    Groups all the entries in the specified queue into ranges containing up limit entries big and returns those ranges. Allows you to incrementally, load all the entries in a queue.

    Attributes
    abstract
    Definition Classes
    Store
  14. def list_queues (callback: (Seq[Long]) ⇒ Unit): Unit

    Gets a listing of all queue entry sequences previously added and reports them to the callback.

    Gets a listing of all queue entry sequences previously added and reports them to the callback.

    Attributes
    abstract
    Definition Classes
    Store
  15. def load_message (messageKey: Long, locator: AtomicReference[Array[Byte]])(callback: (Option[MessageRecord]) ⇒ Unit): Unit

    Loads a delivery with the associated id from persistent storage.

    Loads a delivery with the associated id from persistent storage.

    Attributes
    abstract
    Definition Classes
    Store
  16. def purge (callback: ⇒ Unit): Unit

    Removes all previously stored data.

    Removes all previously stored data.

    Attributes
    abstract
    Definition Classes
    Store
  17. def remove_queue (queueKey: Long)(callback: (Boolean) ⇒ Unit): Unit

    Removes a queue.

    Removes a queue. Success is reported via the callback.

    Attributes
    abstract
    Definition Classes
    Store
  18. def store (uows: Seq[DelayableUOW])(callback: ⇒ Unit): Unit

    Attributes
    protected abstract

Concrete Value Members

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

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

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

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

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

    Attributes
    final
    Definition Classes
    Any
  6. var _serviceFailure : Exception

    Attributes
    protected
    Definition Classes
    BaseService
  7. var _service_state : State

    Attributes
    protected
    Definition Classes
    BaseService
  8. val aggregator : AggregatingExecutor

  9. def asInstanceOf [T0] : T0

    Attributes
    final
    Definition Classes
    Any
  10. def assert_executing : Unit

    Definition Classes
    Dispatched
  11. var canceled_add_message : Long

  12. var canceled_enqueue : Long

  13. def clone (): AnyRef

    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws()
  14. var commit_latency : TimeMetric

  15. val commit_latency_counter : TimeCounter

  16. def create_uow (): DelayableUOW

    Creates a store uow which is used to perform persistent operations as unit of work.

    Creates a store uow which is used to perform persistent operations as unit of work.

    Definition Classes
    DelayingStoreSupportStore
  17. var delayed_uows : HashMap[Int, DelayableUOW]

  18. val dispatch_queue : DispatchQueue

    Definition Classes
    DelayingStoreSupport → Dispatched
  19. def drain_flush_message : Unit

  20. def drain_flushes : Unit

  21. def drain_uows : Unit

  22. def eq (arg0: AnyRef): Boolean

    Attributes
    final
    Definition Classes
    AnyRef
  23. def equals (arg0: Any): Boolean

    Definition Classes
    AnyRef → Any
  24. def fill_store_status (rc: StoreStatusDTO): Unit

    Attributes
    protected
  25. def finalize (): Unit

    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws()
  26. var flush_latency : TimeMetric

  27. val flush_latency_counter : TimeCounter

  28. def flush_message (message_key: Long)(cb: ⇒ Unit): Unit

    Removes a the delivery associated with the provided from any internal buffers/caches.

    Removes a the delivery associated with the provided from any internal buffers/caches. The callback is executed once, the message is no longer buffered.

    Definition Classes
    DelayingStoreSupportStore
  29. val flush_message_source : CustomDispatchSource[(Long, () ⇒ Unit), ListBuffer[(Long, () ⇒ Unit)]]

  30. val flush_source : CustomDispatchSource[DelayableUOW, ListBuffer[DelayableUOW]]

  31. def getClass (): java.lang.Class[_]

    Attributes
    final
    Definition Classes
    AnyRef
  32. def hashCode (): Int

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

    Attributes
    final
    Definition Classes
    Any
  34. def key (x: QueueEntryRecord): (Long, Long)

  35. var message_load_batch_size : IntMetric

  36. val message_load_batch_size_counter : IntMetricCounter

  37. var message_load_latency : TimeMetric

  38. val message_load_latency_counter : TimeCounter

  39. var metric_canceled_enqueue_counter : Long

  40. var metric_canceled_message_counter : Long

  41. var metric_flushed_enqueue_counter : Long

  42. var metric_flushed_message_counter : Long

  43. def ne (arg0: AnyRef): Boolean

    Attributes
    final
    Definition Classes
    AnyRef
  44. val next_batch_id : AtomicInteger

  45. def notify (): Unit

    Attributes
    final
    Definition Classes
    AnyRef
  46. def notifyAll (): Unit

    Attributes
    final
    Definition Classes
    AnyRef
  47. var pending_enqueues : HashMap[(Long, Long), MessageAction]

  48. var pending_stores : HashMap[Long, MessageAction]

  49. var range_load_latency : TimeMetric

  50. val range_load_latency_counter : TimeCounter

  51. def serviceFailure : Exception

    Definition Classes
    BaseService
  52. def service_state : State

    Definition Classes
    BaseService
  53. def start (on_completed: Runnable): Unit

    Attributes
    final
    Definition Classes
    BaseService → Service
  54. def start (): Unit

    Attributes
    final
    Definition Classes
    BaseService → Service
  55. def start (func: ⇒ Unit): Unit

    Definition Classes
    ServiceTrait
  56. def stop (on_completed: Runnable): Unit

    Attributes
    final
    Definition Classes
    BaseService → Service
  57. def stop (): Unit

    Attributes
    final
    Definition Classes
    BaseService → Service
  58. def stop (func: ⇒ Unit): Unit

    Definition Classes
    ServiceTrait
  59. def store_completed (uows: ListBuffer[DelayableUOW]): Unit

  60. def synchronized [T0] (arg0: ⇒ T0): T0

    Attributes
    final
    Definition Classes
    AnyRef
  61. implicit def toIntMetricDTO (m: IntMetric): IntMetricDTO

    Attributes
    implicit
  62. def toString (): String

    Definition Classes
    AnyRef → Any
  63. implicit def toTimeMetricDTO (m: TimeMetric): TimeMetricDTO

    Attributes
    implicit
  64. val uow_source : CustomDispatchSource[DelayableUOW, ListBuffer[DelayableUOW]]

  65. def wait (): Unit

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

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

    Attributes
    final
    Definition Classes
    AnyRef
    Annotations
    @throws()
  68. def zero_copy_buffer_allocator (): ZeroCopyBufferAllocator

    Definition Classes
    Store

Inherited from BaseService

Inherited from Dispatched

Inherited from Store

Inherited from ServiceTrait

Inherited from Service

Inherited from AnyRef

Inherited from Any