Index
All Classes and Interfaces|All Packages|Serialized Form
A
- accumulate(V) - Method in interface com.rpl.rama.ops.RamaAccumulatorAgg0
-
Combine current aggregated value with new input to produce new aggregated value
- accumulate(V, T0) - Method in interface com.rpl.rama.ops.RamaAccumulatorAgg1
-
Combine current aggregated value with new input to produce new aggregated value
- accumulate(V, T0, T1) - Method in interface com.rpl.rama.ops.RamaAccumulatorAgg2
-
Combine current aggregated value with new input to produce new aggregated value
- accumulate(V, T0, T1, T2) - Method in interface com.rpl.rama.ops.RamaAccumulatorAgg3
-
Combine current aggregated value with new input to produce new aggregated value
- accumulate(V, T0, T1, T2, T3) - Method in interface com.rpl.rama.ops.RamaAccumulatorAgg4
-
Combine current aggregated value with new input to produce new aggregated value
- accumulate(V, T0, T1, T2, T3, T4) - Method in interface com.rpl.rama.ops.RamaAccumulatorAgg5
-
Combine current aggregated value with new input to produce new aggregated value
- accumulate(V, T0, T1, T2, T3, T4, T5) - Method in interface com.rpl.rama.ops.RamaAccumulatorAgg6
-
Combine current aggregated value with new input to produce new aggregated value
- accumulate(V, T0, T1, T2, T3, T4, T5, T6) - Method in interface com.rpl.rama.ops.RamaAccumulatorAgg7
-
Combine current aggregated value with new input to produce new aggregated value
- accumulate(V, T0, T1, T2, T3, T4, T5, T6, T7) - Method in interface com.rpl.rama.ops.RamaAccumulatorAgg8
-
Combine current aggregated value with new input to produce new aggregated value
- accumulator(RamaAccumulatorAgg0) - Static method in interface com.rpl.rama.Agg
-
Use a custom accumulator of zero arguments as an aggregator.
- accumulator(RamaAccumulatorAgg1, Object) - Static method in interface com.rpl.rama.Agg
-
Use a custom accumulator of one argument as an aggregator.
- accumulator(RamaAccumulatorAgg2, Object, Object) - Static method in interface com.rpl.rama.Agg
-
Use a custom accumulator of two arguments as an aggregator.
- accumulator(RamaAccumulatorAgg3, Object, Object, Object) - Static method in interface com.rpl.rama.Agg
-
Use a custom accumulator of three arguments as an aggregator.
- accumulator(RamaAccumulatorAgg4, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Agg
-
Use a custom accumulator of four arguments as an aggregator.
- accumulator(RamaAccumulatorAgg5, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Agg
-
Use a custom accumulator of five arguments as an aggregator.
- accumulator(RamaAccumulatorAgg6, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Agg
-
Use a custom accumulator of six arguments as an aggregator.
- accumulator(RamaAccumulatorAgg7, Object, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Agg
-
Use a custom accumulator of seven arguments as an aggregator.
- accumulator(RamaAccumulatorAgg8, Object, Object, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Agg
-
Use a custom accumulator of eight arguments as an aggregator.
- ACK - Enum constant in enum class com.rpl.rama.AckLevel
-
Waits for confirmation the append has been received and replicated on the target depot partition and that all colocated stream topologies have processed the append.
- AckLevel - Enum Class in com.rpl.rama
-
Ack levels for use with
depot clients
. - ackReturn(Object) - Static method in interface com.rpl.rama.Block
-
Accumulate value according to depot source options to return with depot appends done with AckLevel.ACK
- ackReturn(Object) - Method in interface com.rpl.rama.Block.Impl
-
Accumulate value according to depot source options to return with depot appends done with AckLevel.ACK
- ackReturn(Object) - Method in interface com.rpl.rama.Case.Impl
-
Accumulate value according to depot source options to return with depot appends done with AckLevel.ACK
- ackReturn(Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Accumulate value according to depot source options to return with depot appends done with AckLevel.ACK
- ackReturnAgg(RamaAccumulatorAgg1) - Static method in interface com.rpl.rama.module.StreamSourceOptions
-
Specifies aggregator to use for ack returns for processing off of this depot.
- ackReturnAgg(RamaAccumulatorAgg1) - Method in interface com.rpl.rama.module.StreamSourceOptions.Impl
-
Specifies aggregator to use for ack returns for processing off of this depot.
- ackReturnAgg(RamaCombinerAgg) - Static method in interface com.rpl.rama.module.StreamSourceOptions
-
Specifies aggregator to use for ack returns for processing off of this depot.
- ackReturnAgg(RamaCombinerAgg) - Method in interface com.rpl.rama.module.StreamSourceOptions.Impl
-
Specifies aggregator to use for ack returns for processing off of this depot.
- ackReturnAgg(RamaFunction1<Object, Agg>) - Static method in interface com.rpl.rama.module.StreamSourceOptions
-
Specifies aggregator to use for ack returns for processing off of this depot.
- ackReturnAgg(RamaFunction1<Object, Agg>) - Method in interface com.rpl.rama.module.StreamSourceOptions.Impl
-
Specifies aggregator to use for ack returns for processing off of this depot.
- ACTIVE - Enum constant in enum class com.rpl.rama.ProxyState.Status
- addFixedKeys(Object...) - Method in interface com.rpl.rama.PState.MigratedSchema
-
Migration option to specify keys being added to a
fixedKeysSchema
. - afterElem() - Static method in interface com.rpl.rama.Path
-
Navigates on a list to void element at end.
- afterElem() - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a list to void element at end.
- agg(Agg) - Static method in interface com.rpl.rama.Block
-
Aggregates input in a
batch block
to a single value. - agg(Agg) - Method in interface com.rpl.rama.Block.Impl
-
Aggregates input in a
batch block
to a single value. - agg(Agg) - Method in interface com.rpl.rama.Case.Impl
-
Aggregates input in a
batch block
to a single value. - agg(Agg) - Method in interface com.rpl.rama.SubSource.Impl
-
Aggregates input in a
batch block
to a single value. - agg(String, Agg) - Static method in interface com.rpl.rama.Block
-
Update PState partition on current task with given aggregator.
- agg(String, Agg) - Method in interface com.rpl.rama.Block.Impl
-
Update PState partition on current task with given aggregator.
- agg(String, Agg) - Method in interface com.rpl.rama.Case.Impl
-
Update PState partition on current task with given aggregator.
- agg(String, Agg) - Method in interface com.rpl.rama.SubSource.Impl
-
Update PState partition on current task with given aggregator.
- Agg - Interface in com.rpl.rama
-
Used for specifying aggregators in Rama topologies in conjunction with
agg
orcompoundAgg
methods - AggOrCompoundAgg - Interface in com.rpl.rama.ops
- all() - Static method in interface com.rpl.rama.Path
-
Navigates to every element of a collection.
- all() - Method in interface com.rpl.rama.Path.Impl
-
Navigates to every element of a collection.
- allowYield() - Static method in interface com.rpl.rama.SelectOptions
-
Allow the select call to yield during execution in order to not run for too long at a time on the task thread.
- allowYield() - Method in class com.rpl.rama.SelectOptions.CaptureSelectOptions
- allowYield() - Method in interface com.rpl.rama.SelectOptions.Impl
- allPartition() - Static method in interface com.rpl.rama.Block
-
Executes subsequent code on all tasks in module
- allPartition() - Method in interface com.rpl.rama.Block.Impl
-
Executes subsequent code on all tasks in module
- allPartition() - Method in interface com.rpl.rama.Case.Impl
-
Executes subsequent code on all tasks in module
- allPartition() - Method in interface com.rpl.rama.SubSource.Impl
-
Executes subsequent code on all tasks in module
- allPartition(String) - Static method in interface com.rpl.rama.Block
-
Executes subsequent code on all partitions of given depot or PState
- allPartition(String) - Method in interface com.rpl.rama.Block.Impl
-
Executes subsequent code on all partitions of given depot or PState
- allPartition(String) - Method in interface com.rpl.rama.Case.Impl
-
Executes subsequent code on all partitions of given depot or PState
- allPartition(String) - Method in interface com.rpl.rama.SubSource.Impl
-
Executes subsequent code on all partitions of given depot or PState
- anchor(String) - Static method in interface com.rpl.rama.Block
-
Attaches a no-op node with the given anchor
- anchor(String) - Method in interface com.rpl.rama.Block.Impl
-
Attaches a no-op node with the given anchor
- anchor(String) - Method in interface com.rpl.rama.Case.Impl
-
Attaches a no-op node with the given anchor
- anchor(String) - Method in interface com.rpl.rama.SubSource.Impl
-
Attaches a no-op node with the given anchor
- and(Object) - Static method in interface com.rpl.rama.Agg
-
Applies "and" operator to all input.
- AND - Static variable in class com.rpl.rama.ops.Ops
-
"and" operator based on values being "truthy" (not null or false).
- append(Object) - Method in interface com.rpl.rama.Depot
-
Append data to depot using
AckLevel.ACK
. - append(Object, AckLevel) - Method in interface com.rpl.rama.Depot
-
Append data to depot using specified
AckLevel
. - APPEND_ACK - Enum constant in enum class com.rpl.rama.AckLevel
-
Waits for confirmation the append has been received and replicated on the target depot partition.
- appendAsync(Object) - Method in interface com.rpl.rama.Depot
-
Append data to depot using
AckLevel.ACK
. - appendAsync(Object, AckLevel) - Method in interface com.rpl.rama.Depot
-
Append data to depot using specified
AckLevel
. - AppendDiff - Class in com.rpl.rama.diffs
-
Represents an unknown value being appended to a sequence.
- AppendDiff(int) - Constructor for class com.rpl.rama.diffs.AppendDiff
- AppendDiff.Processor - Interface in com.rpl.rama.diffs
- ascending() - Method in interface com.rpl.rama.ops.TopMonotonicAgg
-
Sort results in ascending order rather than descending order
- atomicBlock(Block) - Static method in interface com.rpl.rama.Block
-
Runs subblock until it completes synchronously.
- atomicBlock(Block) - Method in interface com.rpl.rama.Block.Impl
-
Runs subblock until it completes synchronously.
- atomicBlock(Block) - Method in interface com.rpl.rama.Case.Impl
-
Runs subblock until it completes synchronously.
- atomicBlock(Block) - Method in interface com.rpl.rama.SubSource.Impl
-
Runs subblock until it completes synchronously.
- average(Object) - Static method in interface com.rpl.rama.Agg
-
Averages input into a java.lang.Long.
B
- BackupProvider - Interface in com.rpl.rama.backup
-
This interface defines the functionality required in order to create, store and manage Rama cluster backups.
- BackupProvider.KeysPage - Class in com.rpl.rama.backup
- BackupProviderTester - Class in com.rpl.rama.backup
-
Provide a test implementation for a backup provider implementation.
- BackupProviderTester() - Constructor for class com.rpl.rama.backup.BackupProviderTester
- batchBlock(Block) - Static method in interface com.rpl.rama.Block
-
Specifies a batch block.
- batchBlock(Block) - Method in interface com.rpl.rama.Block.Impl
-
Specifies a batch block.
- batchBlock(Block) - Method in interface com.rpl.rama.Case.Impl
-
Specifies a batch block.
- batchBlock(Block) - Method in interface com.rpl.rama.SubSource.Impl
-
Specifies a batch block.
- beforeElem() - Static method in interface com.rpl.rama.Path
-
Navigates on a list to void element at beginning.
- beforeElem() - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a list to void element at beginning.
- beforeIndex(Object) - Static method in interface com.rpl.rama.Path
-
Navigates on list to void element before an index.
- beforeIndex(Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates on list to void element before an index.
- beginning() - Static method in interface com.rpl.rama.Path
-
Navigates on a list to empty subsequence at beginning.
- beginning() - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a list to empty subsequence at beginning.
- Block - Interface in com.rpl.rama
-
Core API for specifying dataflow code using the builder pattern.
- Block.Impl - Interface in com.rpl.rama
- Block.MultiOutImpl - Interface in com.rpl.rama
- Block.Out - Interface in com.rpl.rama
- Block.OutImpl - Interface in com.rpl.rama
- branch(String, Block) - Static method in interface com.rpl.rama.Block
- branch(String, Block) - Method in interface com.rpl.rama.Block.Impl
- branch(String, Block) - Method in interface com.rpl.rama.Case.Impl
- branch(String, Block) - Method in interface com.rpl.rama.SubSource.Impl
C
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.AppendDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.DestroyedDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.Diff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.KeyChangeDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.KeyDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.KeyRemoveDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.KeysDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.KeysRemoveDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.MultiDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.MultiSetAddDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.MultiSetRemoveDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.NewValueDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.ResyncDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.SequenceChangeDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.SequenceIndexChangeDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.SequenceIndexChangesDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.SequenceIndexRemoveDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.SequenceInsertDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.SequenceInsertsDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.SequenceReorderDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.SetAddDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.SetRemoveDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.UngracefulTerminationDiff
- canProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.UnknownDiff
- CapturedEmit(String, Object...) - Constructor for class com.rpl.rama.test.MockOutputCollector.CapturedEmit
- CapturedSortedRangeFromOptions() - Constructor for class com.rpl.rama.SortedRangeFromOptions.CapturedSortedRangeFromOptions
- CapturedSortedRangeOptions() - Constructor for class com.rpl.rama.SortedRangeOptions.CapturedSortedRangeOptions
- CapturedSortedRangeToOptions() - Constructor for class com.rpl.rama.SortedRangeToOptions.CapturedSortedRangeToOptions
- CapturedSubindexOptions() - Constructor for class com.rpl.rama.SubindexOptions.CapturedSubindexOptions
- captureNewValInto(String) - Method in interface com.rpl.rama.Agg
-
Captures updated value of aggregated location into var for post-agg phase of a batch block.
- CaptureSelectOptions() - Constructor for class com.rpl.rama.SelectOptions.CaptureSelectOptions
- Case - Interface in com.rpl.rama
-
Used to create cases for
Block.cond(com.rpl.rama.Case...)
- Case.Impl - Interface in com.rpl.rama
- Case.MultiOutImpl - Interface in com.rpl.rama
- Case.Out - Interface in com.rpl.rama
- Case.OutImpl - Interface in com.rpl.rama
- change(T, Diff, T) - Method in interface com.rpl.rama.ProxyState.Callback
-
Callback method for changes to this value
- choosePartitionIndex(T, int) - Method in interface com.rpl.rama.Depot.Partitioning
-
Computes partition number for append based on data and number of partitions in depot
- CLASS - Static variable in class com.rpl.rama.ops.Ops
-
Emits
Class
of argument. - close() - Method in class com.rpl.rama.integration.ManagedResource
-
Closes the resource if it's an instance of java.io.Closeable.
- clusterDepot(String, String) - Method in interface com.rpl.rama.cluster.ClusterManagerBase
-
Retrieve client for a Depot
- clusterDepot(String, String, String) - Method in interface com.rpl.rama.RamaModule.Setup
-
Defines a mirror depot that accesses a depot on another module.
- ClusterManagerBase - Interface in com.rpl.rama.cluster
-
Interface for retrieving depots, PStates, and query topology clients from a real cluster or
InProcessCluster
- clusterPState(String, String) - Method in interface com.rpl.rama.cluster.ClusterManagerBase
-
Retrieve client for a PState
- clusterPState(String, String, String) - Method in interface com.rpl.rama.RamaModule.Setup
-
Defines a mirror PState that accesses a PState on another module.
- clusterQuery(String, String) - Method in interface com.rpl.rama.cluster.ClusterManagerBase
-
Retrieve client for a query topology
- clusterQuery(String, String, String) - Method in interface com.rpl.rama.RamaModule.Setup
-
Defines a query topology reference for invoking a query topology on another module.
- collect(Path) - Static method in interface com.rpl.rama.Path
-
Collects a list of values selected with given path from current point.
- collect(Path) - Method in interface com.rpl.rama.Path.Impl
-
Collects a list of values selected with given path from current point.
- collectOne(Path) - Static method in interface com.rpl.rama.Path
-
Collects a single value selected with given path from current point.
- collectOne(Path) - Method in interface com.rpl.rama.Path.Impl
-
Collects a single value selected with given path from current point.
- com.rpl.rama - package com.rpl.rama
- com.rpl.rama.backup - package com.rpl.rama.backup
- com.rpl.rama.cluster - package com.rpl.rama.cluster
- com.rpl.rama.diffs - package com.rpl.rama.diffs
- com.rpl.rama.integration - package com.rpl.rama.integration
- com.rpl.rama.module - package com.rpl.rama.module
- com.rpl.rama.object - package com.rpl.rama.object
- com.rpl.rama.ops - package com.rpl.rama.ops
- com.rpl.rama.test - package com.rpl.rama.test
- combine(T, T) - Method in interface com.rpl.rama.ops.RamaCombinerAgg
-
Combine two values into an aggregated value
- combiner(RamaCombinerAgg, Object) - Static method in interface com.rpl.rama.Agg
-
Use a custom combiner as an aggregator
- compoundAgg(CompoundAgg) - Static method in interface com.rpl.rama.Block
-
Aggregates input in a
batch block
to a single value. - compoundAgg(CompoundAgg) - Method in interface com.rpl.rama.Block.Impl
-
Aggregates input in a
batch block
to a single value. - compoundAgg(CompoundAgg) - Method in interface com.rpl.rama.Case.Impl
-
Aggregates input in a
batch block
to a single value. - compoundAgg(CompoundAgg) - Method in interface com.rpl.rama.SubSource.Impl
-
Aggregates input in a
batch block
to a single value. - compoundAgg(String, CompoundAgg) - Static method in interface com.rpl.rama.Block
-
Update PState partition on current task with given aggregation template.
- compoundAgg(String, CompoundAgg) - Method in interface com.rpl.rama.Block.Impl
-
Update PState partition on current task with given aggregation template.
- compoundAgg(String, CompoundAgg) - Method in interface com.rpl.rama.Case.Impl
-
Update PState partition on current task with given aggregation template.
- compoundAgg(String, CompoundAgg) - Method in interface com.rpl.rama.SubSource.Impl
-
Update PState partition on current task with given aggregation template.
- CompoundAgg - Interface in com.rpl.rama
-
Static methods for making aggregation templates for
Block.compoundAgg(com.rpl.rama.CompoundAgg)
. - cond(Case...) - Static method in interface com.rpl.rama.Block
-
Evaluates condition for each
Case
in order. - cond(Case...) - Method in interface com.rpl.rama.Block.Impl
-
Evaluates condition for each
Case
in order. - cond(Case...) - Method in interface com.rpl.rama.Case.Impl
-
Evaluates condition for each
Case
in order. - cond(Case...) - Method in interface com.rpl.rama.SubSource.Impl
-
Evaluates condition for each
Case
in order. - Constant - Class in com.rpl.rama
-
Wrapper type to force an object to be a constant in dataflow code.
- Constant(Object) - Constructor for class com.rpl.rama.Constant
- CONTAINS - Static variable in class com.rpl.rama.ops.Ops
-
Arguments are a collection and an object and returns boolean true or false if the object is contained in the collection.
- continueLoop(Object...) - Static method in interface com.rpl.rama.Block
-
Executes another iteration of the loop.
- continueLoop(Object...) - Method in interface com.rpl.rama.Block.Impl
-
Executes another iteration of the loop.
- continueLoop(Object...) - Method in interface com.rpl.rama.Case.Impl
-
Executes another iteration of the loop.
- continueLoop(Object...) - Method in interface com.rpl.rama.SubSource.Impl
-
Executes another iteration of the loop.
- count() - Static method in interface com.rpl.rama.Agg
-
Counts input into a java.lang.Long
- create() - Static method in interface com.rpl.rama.Block
-
Creates an empty Block that can have additional code attached.
- create() - Static method in interface com.rpl.rama.LoopVars
-
Creates an empty LoopVars.
- create() - Static method in interface com.rpl.rama.module.MicrobatchSourceOptions
-
Creates an empty MicrobatchSourceOptions.
- create() - Static method in interface com.rpl.rama.module.StreamSourceOptions
-
Creates an empty StreamSourceOptions.
- create() - Static method in interface com.rpl.rama.Path
-
Creates an empty Path.
- create() - Static method in interface com.rpl.rama.SelectOptions
-
Creates an empty SubiSelectOptionsndexOptions.
- create() - Static method in interface com.rpl.rama.SortedRangeFromOptions
-
Creates an empty SortedRangeFromOptions.
- create() - Static method in interface com.rpl.rama.SortedRangeOptions
-
Creates an empty SortedRangeOptions.
- create() - Static method in interface com.rpl.rama.SortedRangeToOptions
-
Creates an empty SortedRangeToOptions.
- create() - Static method in interface com.rpl.rama.SubindexOptions
-
Creates an empty SubindexOptions.
- create() - Static method in interface com.rpl.rama.test.InProcessCluster
-
Creates an InProcessCluster
- create() - Static method in interface com.rpl.rama.test.UpdateOptions
-
Create empty instance
- create(int, String...) - Static method in interface com.rpl.rama.ops.LimitAgg
-
Creates a limit aggregator specification
- create(PState.Schema) - Static method in interface com.rpl.rama.test.TestPState
-
Creates a TestPState with the given schema.
- create(Class) - Static method in interface com.rpl.rama.SubSource
-
Create a subSource case matching on the given type exactly.
- create(Class) - Static method in interface com.rpl.rama.test.TestPState
-
Creates a TestPState with the given schema.
- create(Object) - Static method in interface com.rpl.rama.Case
-
Create a case matching on the given condition.
- create(List<Class>) - Static method in interface com.rpl.rama.test.InProcessCluster
-
Creates an InProcessCluster with the specified
RamaCustomSerialization
implementations registered for all launched modules - CURRENT_MICROBATCH_ID - Static variable in class com.rpl.rama.ops.Ops
-
Returns ID of current microbatch attempt.
- CURRENT_TASK_ID - Static variable in class com.rpl.rama.ops.Ops
-
Emits task ID where event is running
- CURRENT_TOPOLOGY_TYPE - Static variable in class com.rpl.rama.ops.Ops
-
Returns the type of the current topology ("stream", "microbatch", or "query"), or else null.
- customNav(Navigator) - Static method in interface com.rpl.rama.Path
-
Adds custom navigator implementation to Path
- customNav(Navigator) - Method in interface com.rpl.rama.Path.Impl
-
Adds custom navigator implementation to Path
- customNavBuilder(RamaFunction0<Navigator>) - Static method in interface com.rpl.rama.Path
-
Adds a custom navigator built dynamically with the provided function of zero arguments.
- customNavBuilder(RamaFunction0<Navigator>) - Method in interface com.rpl.rama.Path.Impl
-
Adds a custom navigator built dynamically with the provided function of zero arguments.
- customNavBuilder(RamaFunction1<T0, Navigator>, Object) - Static method in interface com.rpl.rama.Path
-
Adds a custom navigator built dynamically with the provided function of one argument.
- customNavBuilder(RamaFunction1<T0, Navigator>, Object) - Method in interface com.rpl.rama.Path.Impl
-
Adds a custom navigator built dynamically with the provided function of one argument.
- customNavBuilder(RamaFunction2<T0, T1, Navigator>, Object, Object) - Static method in interface com.rpl.rama.Path
-
Adds a custom navigator built dynamically with the provided function of two arguments.
- customNavBuilder(RamaFunction2<T0, T1, Navigator>, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Adds a custom navigator built dynamically with the provided function of two arguments.
- customNavBuilder(RamaFunction3<T0, T1, T2, Navigator>, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Adds a custom navigator built dynamically with the provided function of three arguments.
- customNavBuilder(RamaFunction3<T0, T1, T2, Navigator>, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Adds a custom navigator built dynamically with the provided function of three arguments.
- customNavBuilder(RamaFunction4<T0, T1, T2, T3, Navigator>, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Adds a custom navigator built dynamically with the provided function of four arguments.
- customNavBuilder(RamaFunction4<T0, T1, T2, T3, Navigator>, Object, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Adds a custom navigator built dynamically with the provided function of four arguments.
- customNavBuilder(RamaFunction5<T0, T1, T2, T3, T4, Navigator>, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Adds a custom navigator built dynamically with the provided function of five arguments.
- customNavBuilder(RamaFunction5<T0, T1, T2, T3, T4, Navigator>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Adds a custom navigator built dynamically with the provided function of five arguments.
- customNavBuilder(RamaFunction6<T0, T1, T2, T3, T4, T5, Navigator>, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Adds a custom navigator built dynamically with the provided function of six arguments.
- customNavBuilder(RamaFunction6<T0, T1, T2, T3, T4, T5, Navigator>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Adds a custom navigator built dynamically with the provided function of six arguments.
- customNavBuilder(RamaFunction7<T0, T1, T2, T3, T4, T5, T6, Navigator>, Object, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Adds a custom navigator built dynamically with the provided function of seven arguments.
- customNavBuilder(RamaFunction7<T0, T1, T2, T3, T4, T5, T6, Navigator>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Adds a custom navigator built dynamically with the provided function of seven arguments.
- customNavBuilder(RamaFunction8<T0, T1, T2, T3, T4, T5, T6, T7, Navigator>, Object, Object, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Adds a custom navigator built dynamically with the provided function of eight arguments.
- customNavBuilder(RamaFunction8<T0, T1, T2, T3, T4, T5, T6, T7, Navigator>, Object, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Adds a custom navigator built dynamically with the provided function of eight arguments.
- customPartition(RamaFunction1<Integer, Integer>) - Static method in interface com.rpl.rama.Block
-
Changes task to task ID specified by custom partitioner function with one argument.
- customPartition(RamaFunction1<Integer, Integer>) - Method in interface com.rpl.rama.Block.Impl
-
Changes task to task ID specified by custom partitioner function with one argument.
- customPartition(RamaFunction1<Integer, Integer>) - Method in interface com.rpl.rama.Case.Impl
-
Changes task to task ID specified by custom partitioner function with one argument.
- customPartition(RamaFunction1<Integer, Integer>) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes task to task ID specified by custom partitioner function with one argument.
- customPartition(RamaFunction2<Integer, T0, Integer>, Object) - Static method in interface com.rpl.rama.Block
-
Changes task to task ID specified by custom partitioner function with two arguments.
- customPartition(RamaFunction2<Integer, T0, Integer>, Object) - Method in interface com.rpl.rama.Block.Impl
-
Changes task to task ID specified by custom partitioner function with two arguments.
- customPartition(RamaFunction2<Integer, T0, Integer>, Object) - Method in interface com.rpl.rama.Case.Impl
-
Changes task to task ID specified by custom partitioner function with two arguments.
- customPartition(RamaFunction2<Integer, T0, Integer>, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes task to task ID specified by custom partitioner function with two arguments.
- customPartition(RamaFunction3<Integer, T0, T1, Integer>, Object, Object) - Static method in interface com.rpl.rama.Block
-
Changes task to task ID specified by custom partitioner function with three arguments.
- customPartition(RamaFunction3<Integer, T0, T1, Integer>, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Changes task to task ID specified by custom partitioner function with three arguments.
- customPartition(RamaFunction3<Integer, T0, T1, Integer>, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Changes task to task ID specified by custom partitioner function with three arguments.
- customPartition(RamaFunction3<Integer, T0, T1, Integer>, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes task to task ID specified by custom partitioner function with three arguments.
- customPartition(RamaFunction4<Integer, T0, T1, T2, Integer>, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Changes task to task ID specified by custom partitioner function with four arguments.
- customPartition(RamaFunction4<Integer, T0, T1, T2, Integer>, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Changes task to task ID specified by custom partitioner function with four arguments.
- customPartition(RamaFunction4<Integer, T0, T1, T2, Integer>, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Changes task to task ID specified by custom partitioner function with four arguments.
- customPartition(RamaFunction4<Integer, T0, T1, T2, Integer>, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes task to task ID specified by custom partitioner function with four arguments.
- customPartition(RamaFunction5<Integer, T0, T1, T2, T3, Integer>, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Changes task to task ID specified by custom partitioner function with five arguments.
- customPartition(RamaFunction5<Integer, T0, T1, T2, T3, Integer>, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Changes task to task ID specified by custom partitioner function with five arguments.
- customPartition(RamaFunction5<Integer, T0, T1, T2, T3, Integer>, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Changes task to task ID specified by custom partitioner function with five arguments.
- customPartition(RamaFunction5<Integer, T0, T1, T2, T3, Integer>, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes task to task ID specified by custom partitioner function with five arguments.
- customPartition(RamaFunction6<Integer, T0, T1, T2, T3, T4, Integer>, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Changes task to task ID specified by custom partitioner function with six arguments.
- customPartition(RamaFunction6<Integer, T0, T1, T2, T3, T4, Integer>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Changes task to task ID specified by custom partitioner function with six arguments.
- customPartition(RamaFunction6<Integer, T0, T1, T2, T3, T4, Integer>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Changes task to task ID specified by custom partitioner function with six arguments.
- customPartition(RamaFunction6<Integer, T0, T1, T2, T3, T4, Integer>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes task to task ID specified by custom partitioner function with six arguments.
- customPartition(RamaFunction7<Integer, T0, T1, T2, T3, T4, T5, Integer>, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Changes task to task ID specified by custom partitioner function with seven arguments.
- customPartition(RamaFunction7<Integer, T0, T1, T2, T3, T4, T5, Integer>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Changes task to task ID specified by custom partitioner function with seven arguments.
- customPartition(RamaFunction7<Integer, T0, T1, T2, T3, T4, T5, Integer>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Changes task to task ID specified by custom partitioner function with seven arguments.
- customPartition(RamaFunction7<Integer, T0, T1, T2, T3, T4, T5, Integer>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes task to task ID specified by custom partitioner function with seven arguments.
- customPartition(RamaFunction8<Integer, T0, T1, T2, T3, T4, T5, T6, Integer>, Object, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Changes task to task ID specified by custom partitioner function with eight arguments.
- customPartition(RamaFunction8<Integer, T0, T1, T2, T3, T4, T5, T6, Integer>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Changes task to task ID specified by custom partitioner function with eight arguments.
- customPartition(RamaFunction8<Integer, T0, T1, T2, T3, T4, T5, T6, Integer>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Changes task to task ID specified by custom partitioner function with eight arguments.
- customPartition(RamaFunction8<Integer, T0, T1, T2, T3, T4, T5, T6, Integer>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes task to task ID specified by custom partitioner function with eight arguments.
- customPartition(String, RamaFunction1<Integer, Integer>) - Static method in interface com.rpl.rama.Block
-
Changes to task containing PState partition specified by custom partitioner function with one argument.
- customPartition(String, RamaFunction1<Integer, Integer>) - Method in interface com.rpl.rama.Block.Impl
-
Changes to task containing PState partition specified by custom partitioner function with one argument.
- customPartition(String, RamaFunction1<Integer, Integer>) - Method in interface com.rpl.rama.Case.Impl
-
Changes to task containing PState partition specified by custom partitioner function with one argument.
- customPartition(String, RamaFunction1<Integer, Integer>) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes to task containing PState partition specified by custom partitioner function with one argument.
- customPartition(String, RamaFunction2<Integer, T0, Integer>, Object) - Static method in interface com.rpl.rama.Block
-
Changes to task containing PState partition specified by custom partitioner function with two arguments.
- customPartition(String, RamaFunction2<Integer, T0, Integer>, Object) - Method in interface com.rpl.rama.Block.Impl
-
Changes to task containing PState partition specified by custom partitioner function with two arguments.
- customPartition(String, RamaFunction2<Integer, T0, Integer>, Object) - Method in interface com.rpl.rama.Case.Impl
-
Changes to task containing PState partition specified by custom partitioner function with two arguments.
- customPartition(String, RamaFunction2<Integer, T0, Integer>, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes to task containing PState partition specified by custom partitioner function with two arguments.
- customPartition(String, RamaFunction3<Integer, T0, T1, Integer>, Object, Object) - Static method in interface com.rpl.rama.Block
-
Changes to task containing PState partition specified by custom partitioner function with three arguments.
- customPartition(String, RamaFunction3<Integer, T0, T1, Integer>, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Changes to task containing PState partition specified by custom partitioner function with three arguments.
- customPartition(String, RamaFunction3<Integer, T0, T1, Integer>, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Changes to task containing PState partition specified by custom partitioner function with three arguments.
- customPartition(String, RamaFunction3<Integer, T0, T1, Integer>, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes to task containing PState partition specified by custom partitioner function with three arguments.
- customPartition(String, RamaFunction4<Integer, T0, T1, T2, Integer>, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Changes to task containing PState partition specified by custom partitioner function with four arguments.
- customPartition(String, RamaFunction4<Integer, T0, T1, T2, Integer>, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Changes to task containing PState partition specified by custom partitioner function with four arguments.
- customPartition(String, RamaFunction4<Integer, T0, T1, T2, Integer>, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Changes to task containing PState partition specified by custom partitioner function with four arguments.
- customPartition(String, RamaFunction4<Integer, T0, T1, T2, Integer>, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes to task containing PState partition specified by custom partitioner function with four arguments.
- customPartition(String, RamaFunction5<Integer, T0, T1, T2, T3, Integer>, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Changes to task containing PState partition specified by custom partitioner function with five arguments.
- customPartition(String, RamaFunction5<Integer, T0, T1, T2, T3, Integer>, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Changes to task containing PState partition specified by custom partitioner function with five arguments.
- customPartition(String, RamaFunction5<Integer, T0, T1, T2, T3, Integer>, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Changes to task containing PState partition specified by custom partitioner function with five arguments.
- customPartition(String, RamaFunction5<Integer, T0, T1, T2, T3, Integer>, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes to task containing PState partition specified by custom partitioner function with five arguments.
- customPartition(String, RamaFunction6<Integer, T0, T1, T2, T3, T4, Integer>, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Changes to task containing PState partition specified by custom partitioner function with six arguments.
- customPartition(String, RamaFunction6<Integer, T0, T1, T2, T3, T4, Integer>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Changes to task containing PState partition specified by custom partitioner function with six arguments.
- customPartition(String, RamaFunction6<Integer, T0, T1, T2, T3, T4, Integer>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Changes to task containing PState partition specified by custom partitioner function with six arguments.
- customPartition(String, RamaFunction6<Integer, T0, T1, T2, T3, T4, Integer>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes to task containing PState partition specified by custom partitioner function with six arguments.
- customPartition(String, RamaFunction7<Integer, T0, T1, T2, T3, T4, T5, Integer>, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Changes to task containing PState partition specified by custom partitioner function with seven arguments.
- customPartition(String, RamaFunction7<Integer, T0, T1, T2, T3, T4, T5, Integer>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Changes to task containing PState partition specified by custom partitioner function with seven arguments.
- customPartition(String, RamaFunction7<Integer, T0, T1, T2, T3, T4, T5, Integer>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Changes to task containing PState partition specified by custom partitioner function with seven arguments.
- customPartition(String, RamaFunction7<Integer, T0, T1, T2, T3, T4, T5, Integer>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes to task containing PState partition specified by custom partitioner function with seven arguments.
- customPartition(String, RamaFunction8<Integer, T0, T1, T2, T3, T4, T5, T6, Integer>, Object, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Changes to task containing PState partition specified by custom partitioner function with eight arguments.
- customPartition(String, RamaFunction8<Integer, T0, T1, T2, T3, T4, T5, T6, Integer>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Changes to task containing PState partition specified by custom partitioner function with eight arguments.
- customPartition(String, RamaFunction8<Integer, T0, T1, T2, T3, T4, T5, T6, Integer>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Changes to task containing PState partition specified by custom partitioner function with eight arguments.
- customPartition(String, RamaFunction8<Integer, T0, T1, T2, T3, T4, T5, T6, Integer>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes to task containing PState partition specified by custom partitioner function with eight arguments.
D
- DAYS - Enum constant in enum class com.rpl.rama.module.OffsetAgo
-
Start from first record added after this many days in the past
- DEC - Static variable in class com.rpl.rama.ops.Ops
-
Emits one less than input value as an
Integer
- DEC_LONG - Static variable in class com.rpl.rama.ops.Ops
-
Emits one less than input value as a
Long
- declareDepot(String, NativeDepotPartitioning) - Method in interface com.rpl.rama.RamaModule.Setup
-
Defines a depot with the given partitioning scheme.
- declareDepot(String, Class<T>) - Method in interface com.rpl.rama.RamaModule.Setup
-
Defines a depot with the given partitioning scheme.
- declareObject(String, Object) - Method in interface com.rpl.rama.RamaModule.Setup
-
Defines an object to be copied to all tasks.
- declareTickDepot(String, long) - Method in interface com.rpl.rama.RamaModule.Setup
-
Defines a depot that emits at the given frequency of time.
- define(RamaModule.Setup, RamaModule.Topologies) - Method in interface com.rpl.rama.RamaModule
-
Specifies all depots, PStates, ETLs, and query topologies for this module.
- deleteObject(String) - Method in interface com.rpl.rama.backup.BackupProvider
-
Delete the object at the given key in the backup provider.
- Depot - Interface in com.rpl.rama
-
Interface for thread-safe depot clients.
- Depot.Declaration - Interface in com.rpl.rama
-
Builder-style object to specify options when declaring a depot in a module
- Depot.Partitioning<T> - Interface in com.rpl.rama
-
Interface for implementing custom depot partitioners
- depotPartitionAppend(String, Object) - Static method in interface com.rpl.rama.Block
-
Append data to the partition of the depot represented by current task.
- depotPartitionAppend(String, Object) - Method in interface com.rpl.rama.Block.Impl
-
Append data to the partition of the depot represented by current task.
- depotPartitionAppend(String, Object) - Method in interface com.rpl.rama.Case.Impl
-
Append data to the partition of the depot represented by current task.
- depotPartitionAppend(String, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Append data to the partition of the depot represented by current task.
- depotPartitionAppend(String, Object, AckLevel) - Static method in interface com.rpl.rama.Block
-
Append data to the partition of the depot represented by current task.
- depotPartitionAppend(String, Object, AckLevel) - Method in interface com.rpl.rama.Block.Impl
-
Append data to the partition of the depot represented by current task.
- depotPartitionAppend(String, Object, AckLevel) - Method in interface com.rpl.rama.Case.Impl
-
Append data to the partition of the depot represented by current task.
- depotPartitionAppend(String, Object, AckLevel) - Method in interface com.rpl.rama.SubSource.Impl
-
Append data to the partition of the depot represented by current task.
- DepotPartitionInfo - Class in com.rpl.rama.object
-
Information about a depot partition.
- DepotPartitionInfo(long, long) - Constructor for class com.rpl.rama.object.DepotPartitionInfo
- deserialize(DataInput) - Method in interface com.rpl.rama.RamaCustomSerialization
-
Deserialize object
- DestroyedDiff - Class in com.rpl.rama.diffs
-
Final diff sent to proxy callback after
close
is called on it. - DestroyedDiff() - Constructor for class com.rpl.rama.diffs.DestroyedDiff
- DestroyedDiff.Processor - Interface in com.rpl.rama.diffs
- destroyModule(String) - Method in interface com.rpl.rama.test.InProcessCluster
-
Destroy a module
- Diff - Class in com.rpl.rama.diffs
-
Base class for diff data which represents incremental change to a value coming from a
PState.proxy(Path, ProxyState.Callback)
proxy} call on a PState. - Diff() - Constructor for class com.rpl.rama.diffs.Diff
- Diff.Processor - Interface in com.rpl.rama.diffs
- directPartition(Object) - Static method in interface com.rpl.rama.Block
-
Changes to specified task ID
- directPartition(Object) - Method in interface com.rpl.rama.Block.Impl
-
Changes to specified task ID
- directPartition(Object) - Method in interface com.rpl.rama.Case.Impl
-
Changes to specified task ID
- directPartition(Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes to specified task ID
- directPartition(String, Object) - Static method in interface com.rpl.rama.Block
-
Changes to specified partition of the given depot or PState
- directPartition(String, Object) - Method in interface com.rpl.rama.Block.Impl
-
Changes to specified partition of the given depot or PState
- directPartition(String, Object) - Method in interface com.rpl.rama.Case.Impl
-
Changes to specified partition of the given depot or PState
- directPartition(String, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes to specified partition of the given depot or PState
- disallow() - Static method in interface com.rpl.rama.Depot
-
Disallows depot clients from appending to this depot.
- dispenseCollected() - Static method in interface com.rpl.rama.Path
-
Drops all collected values from subsequent navigation
- dispenseCollected() - Method in interface com.rpl.rama.Path.Impl
-
Drops all collected values from subsequent navigation
- DIV - Static variable in class com.rpl.rama.ops.Ops
-
Divides first argument by second argument and emits a
Double
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.AppendDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.DestroyedDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.Diff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.KeyChangeDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.KeyDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.KeyRemoveDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.KeysDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.KeysRemoveDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.MultiDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.MultiSetAddDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.MultiSetRemoveDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.NewValueDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.ResyncDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.SequenceChangeDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.SequenceIndexChangeDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.SequenceIndexChangesDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.SequenceIndexRemoveDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.SequenceInsertDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.SequenceInsertsDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.SequenceReorderDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.SetAddDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.SetRemoveDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.UngracefulTerminationDiff
- doProcess(Diff.Processor) - Method in class com.rpl.rama.diffs.UnknownDiff
E
- each(RamaFunction0<R>) - Static method in interface com.rpl.rama.Block
-
Invokes a function of zero arguments.
- each(RamaFunction0<R>) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a function of zero arguments.
- each(RamaFunction0<R>) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a function of zero arguments.
- each(RamaFunction0<R>) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a function of zero arguments.
- each(RamaFunction1<T0, R>, Object) - Static method in interface com.rpl.rama.Block
-
Invokes a function of one argument.
- each(RamaFunction1<T0, R>, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a function of one argument.
- each(RamaFunction1<T0, R>, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a function of one argument.
- each(RamaFunction1<T0, R>, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a function of one argument.
- each(RamaFunction2<T0, T1, R>, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes a function of two arguments.
- each(RamaFunction2<T0, T1, R>, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a function of two arguments.
- each(RamaFunction2<T0, T1, R>, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a function of two arguments.
- each(RamaFunction2<T0, T1, R>, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a function of two arguments.
- each(RamaFunction3<T0, T1, T2, R>, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes a function of three arguments.
- each(RamaFunction3<T0, T1, T2, R>, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a function of three arguments.
- each(RamaFunction3<T0, T1, T2, R>, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a function of three arguments.
- each(RamaFunction3<T0, T1, T2, R>, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a function of three arguments.
- each(RamaFunction4<T0, T1, T2, T3, R>, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes a function of four arguments.
- each(RamaFunction4<T0, T1, T2, T3, R>, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a function of four arguments.
- each(RamaFunction4<T0, T1, T2, T3, R>, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a function of four arguments.
- each(RamaFunction4<T0, T1, T2, T3, R>, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a function of four arguments.
- each(RamaFunction5<T0, T1, T2, T3, T4, R>, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes a function of five arguments.
- each(RamaFunction5<T0, T1, T2, T3, T4, R>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a function of five arguments.
- each(RamaFunction5<T0, T1, T2, T3, T4, R>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a function of five arguments.
- each(RamaFunction5<T0, T1, T2, T3, T4, R>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a function of five arguments.
- each(RamaFunction6<T0, T1, T2, T3, T4, T5, R>, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes a function of six arguments.
- each(RamaFunction6<T0, T1, T2, T3, T4, T5, R>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a function of six arguments.
- each(RamaFunction6<T0, T1, T2, T3, T4, T5, R>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a function of six arguments.
- each(RamaFunction6<T0, T1, T2, T3, T4, T5, R>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a function of six arguments.
- each(RamaFunction7<T0, T1, T2, T3, T4, T5, T6, R>, Object, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes a function of seven arguments.
- each(RamaFunction7<T0, T1, T2, T3, T4, T5, T6, R>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a function of seven arguments.
- each(RamaFunction7<T0, T1, T2, T3, T4, T5, T6, R>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a function of seven arguments.
- each(RamaFunction7<T0, T1, T2, T3, T4, T5, T6, R>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a function of seven arguments.
- each(RamaFunction8<T0, T1, T2, T3, T4, T5, T6, T7, R>, Object, Object, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes a function of eight arguments.
- each(RamaFunction8<T0, T1, T2, T3, T4, T5, T6, T7, R>, Object, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a function of eight arguments.
- each(RamaFunction8<T0, T1, T2, T3, T4, T5, T6, T7, R>, Object, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a function of eight arguments.
- each(RamaFunction8<T0, T1, T2, T3, T4, T5, T6, T7, R>, Object, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a function of eight arguments.
- each(RamaOperation0) - Static method in interface com.rpl.rama.Block
-
Invokes an operation of zero arguments.
- each(RamaOperation0) - Method in interface com.rpl.rama.Block.Impl
-
Invokes an operation of zero arguments.
- each(RamaOperation0) - Method in interface com.rpl.rama.Case.Impl
-
Invokes an operation of zero arguments.
- each(RamaOperation0) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes an operation of zero arguments.
- each(RamaOperation1<T0>, Object) - Static method in interface com.rpl.rama.Block
-
Invokes an operation of one argument.
- each(RamaOperation1<T0>, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes an operation of one argument.
- each(RamaOperation1<T0>, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes an operation of one argument.
- each(RamaOperation1<T0>, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes an operation of one argument.
- each(RamaOperation2<T0, T1>, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes an operation of two arguments.
- each(RamaOperation2<T0, T1>, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes an operation of two arguments.
- each(RamaOperation2<T0, T1>, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes an operation of two arguments.
- each(RamaOperation2<T0, T1>, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes an operation of two arguments.
- each(RamaOperation3<T0, T1, T2>, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes an operation of three arguments.
- each(RamaOperation3<T0, T1, T2>, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes an operation of three arguments.
- each(RamaOperation3<T0, T1, T2>, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes an operation of three arguments.
- each(RamaOperation3<T0, T1, T2>, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes an operation of three arguments.
- each(RamaOperation4<T0, T1, T2, T3>, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes an operation of four arguments.
- each(RamaOperation4<T0, T1, T2, T3>, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes an operation of four arguments.
- each(RamaOperation4<T0, T1, T2, T3>, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes an operation of four arguments.
- each(RamaOperation4<T0, T1, T2, T3>, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes an operation of four arguments.
- each(RamaOperation5<T0, T1, T2, T3, T4>, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes an operation of five arguments.
- each(RamaOperation5<T0, T1, T2, T3, T4>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes an operation of five arguments.
- each(RamaOperation5<T0, T1, T2, T3, T4>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes an operation of five arguments.
- each(RamaOperation5<T0, T1, T2, T3, T4>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes an operation of five arguments.
- each(RamaOperation6<T0, T1, T2, T3, T4, T5>, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes an operation of six arguments.
- each(RamaOperation6<T0, T1, T2, T3, T4, T5>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes an operation of six arguments.
- each(RamaOperation6<T0, T1, T2, T3, T4, T5>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes an operation of six arguments.
- each(RamaOperation6<T0, T1, T2, T3, T4, T5>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes an operation of six arguments.
- each(RamaOperation7<T0, T1, T2, T3, T4, T5, T6>, Object, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes an operation of seven arguments.
- each(RamaOperation7<T0, T1, T2, T3, T4, T5, T6>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes an operation of seven arguments.
- each(RamaOperation7<T0, T1, T2, T3, T4, T5, T6>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes an operation of seven arguments.
- each(RamaOperation7<T0, T1, T2, T3, T4, T5, T6>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes an operation of seven arguments.
- each(RamaOperation8<T0, T1, T2, T3, T4, T5, T6, T7>, Object, Object, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes an operation of eight arguments.
- each(RamaOperation8<T0, T1, T2, T3, T4, T5, T6, T7>, Object, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes an operation of eight arguments.
- each(RamaOperation8<T0, T1, T2, T3, T4, T5, T6, T7>, Object, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes an operation of eight arguments.
- each(RamaOperation8<T0, T1, T2, T3, T4, T5, T6, T7>, Object, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes an operation of eight arguments.
- eachAsync(RamaFunction0<CompletableFuture>) - Static method in interface com.rpl.rama.Block
-
Invokes a function of zero arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction0<CompletableFuture>) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a function of zero arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction0<CompletableFuture>) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a function of zero arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction0<CompletableFuture>) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a function of zero arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction1<T0, CompletableFuture>, Object) - Static method in interface com.rpl.rama.Block
-
Invokes a function of one argument that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction1<T0, CompletableFuture>, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a function of one argument that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction1<T0, CompletableFuture>, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a function of one argument that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction1<T0, CompletableFuture>, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a function of one argument that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction2<T0, T1, CompletableFuture>, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes a function of two arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction2<T0, T1, CompletableFuture>, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a function of two arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction2<T0, T1, CompletableFuture>, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a function of two arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction2<T0, T1, CompletableFuture>, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a function of two arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction3<T0, T1, T2, CompletableFuture>, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes a function of three arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction3<T0, T1, T2, CompletableFuture>, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a function of three arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction3<T0, T1, T2, CompletableFuture>, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a function of three arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction3<T0, T1, T2, CompletableFuture>, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a function of three arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction4<T0, T1, T2, T3, CompletableFuture>, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes a function of four arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction4<T0, T1, T2, T3, CompletableFuture>, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a function of four arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction4<T0, T1, T2, T3, CompletableFuture>, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a function of four arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction4<T0, T1, T2, T3, CompletableFuture>, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a function of four arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction5<T0, T1, T2, T3, T4, CompletableFuture>, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes a function of five arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction5<T0, T1, T2, T3, T4, CompletableFuture>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a function of five arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction5<T0, T1, T2, T3, T4, CompletableFuture>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a function of five arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction5<T0, T1, T2, T3, T4, CompletableFuture>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a function of five arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction6<T0, T1, T2, T3, T4, T5, CompletableFuture>, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes a function of six arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction6<T0, T1, T2, T3, T4, T5, CompletableFuture>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a function of six arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction6<T0, T1, T2, T3, T4, T5, CompletableFuture>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a function of six arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction6<T0, T1, T2, T3, T4, T5, CompletableFuture>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a function of six arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction7<T0, T1, T2, T3, T4, T5, T6, CompletableFuture>, Object, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes a function of seven arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction7<T0, T1, T2, T3, T4, T5, T6, CompletableFuture>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a function of seven arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction7<T0, T1, T2, T3, T4, T5, T6, CompletableFuture>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a function of seven arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction7<T0, T1, T2, T3, T4, T5, T6, CompletableFuture>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a function of seven arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction8<T0, T1, T2, T3, T4, T5, T6, T7, CompletableFuture>, Object, Object, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Block
-
Invokes a function of eight arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction8<T0, T1, T2, T3, T4, T5, T6, T7, CompletableFuture>, Object, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a function of eight arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction8<T0, T1, T2, T3, T4, T5, T6, T7, CompletableFuture>, Object, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a function of eight arguments that returns its result asynchronously via a returned CompletableFuture.
- eachAsync(RamaFunction8<T0, T1, T2, T3, T4, T5, T6, T7, CompletableFuture>, Object, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a function of eight arguments that returns its result asynchronously via a returned CompletableFuture.
- emit(Object...) - Method in interface com.rpl.rama.ops.OutputCollector
-
Emit any number of fields to the default output stream.
- emit(Object...) - Method in class com.rpl.rama.test.MockOutputCollector
- emitLoop(Object...) - Static method in interface com.rpl.rama.Block
-
Emits from a loop.
- emitLoop(Object...) - Method in interface com.rpl.rama.Block.Impl
-
Emits from a loop.
- emitLoop(Object...) - Method in interface com.rpl.rama.Case.Impl
-
Emits from a loop.
- emitLoop(Object...) - Method in interface com.rpl.rama.SubSource.Impl
-
Emits from a loop.
- emitStream(String, Object...) - Method in interface com.rpl.rama.ops.OutputCollector
-
Emit any number of fields to a named output stream.
- emitStream(String, Object...) - Method in class com.rpl.rama.test.MockOutputCollector
- end() - Static method in interface com.rpl.rama.Path
-
Navigates on a list to empty subsequence at end.
- end() - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a list to empty subsequence at end.
- endOffset(int) - Method in interface com.rpl.rama.integration.ExternalDepot
-
Asynchronously returns the end offset of the given partition index (exclusive).
- EQUAL - Static variable in class com.rpl.rama.ops.Ops
-
Tests whether all arguments are equal and emits boolean true or false.
- equals(Object) - Method in class com.rpl.rama.diffs.AppendDiff
- equals(Object) - Method in class com.rpl.rama.diffs.DestroyedDiff
- equals(Object) - Method in class com.rpl.rama.diffs.KeyChangeDiff
- equals(Object) - Method in class com.rpl.rama.diffs.KeyDiff
- equals(Object) - Method in class com.rpl.rama.diffs.KeyRemoveDiff
- equals(Object) - Method in class com.rpl.rama.diffs.KeysDiff
- equals(Object) - Method in class com.rpl.rama.diffs.KeysRemoveDiff
- equals(Object) - Method in class com.rpl.rama.diffs.MultiDiff
- equals(Object) - Method in class com.rpl.rama.diffs.MultiSetAddDiff
- equals(Object) - Method in class com.rpl.rama.diffs.MultiSetRemoveDiff
- equals(Object) - Method in class com.rpl.rama.diffs.NewValueDiff
- equals(Object) - Method in class com.rpl.rama.diffs.ResyncDiff
- equals(Object) - Method in class com.rpl.rama.diffs.SequenceChangeDiff
- equals(Object) - Method in class com.rpl.rama.diffs.SequenceIndexChangeDiff
- equals(Object) - Method in class com.rpl.rama.diffs.SequenceIndexChangesDiff
- equals(Object) - Method in class com.rpl.rama.diffs.SequenceIndexRemoveDiff
- equals(Object) - Method in class com.rpl.rama.diffs.SequenceInsertDiff
- equals(Object) - Method in class com.rpl.rama.diffs.SequenceInsertsDiff
- equals(Object) - Method in class com.rpl.rama.diffs.SequenceReorderDiff
- equals(Object) - Method in class com.rpl.rama.diffs.SetAddDiff
- equals(Object) - Method in class com.rpl.rama.diffs.SetRemoveDiff
- equals(Object) - Method in class com.rpl.rama.diffs.UngracefulTerminationDiff
- equals(Object) - Method in class com.rpl.rama.diffs.UnknownDiff
- equals(Object) - Method in class com.rpl.rama.test.MockOutputCollector.CapturedEmit
- ETLTopologyBase<T> - Interface in com.rpl.rama.module
-
Base interface for stream and microbatch topologies
- excludeStart() - Method in class com.rpl.rama.SortedRangeFromOptions.CapturedSortedRangeFromOptions
- excludeStart() - Static method in interface com.rpl.rama.SortedRangeFromOptions
-
Excludes the start key from the results (by default it's included).
- excludeStart() - Method in interface com.rpl.rama.SortedRangeFromOptions.Impl
-
Excludes the start key from the results (by default it's included).
- excludeStart() - Method in class com.rpl.rama.SortedRangeOptions.CapturedSortedRangeOptions
- excludeStart() - Static method in interface com.rpl.rama.SortedRangeOptions
-
Excludes the start key from the results (by default it's included).
- excludeStart() - Method in interface com.rpl.rama.SortedRangeOptions.Impl
-
Excludes the start key from the results (by default it's included).
- execute() - Method in interface com.rpl.rama.Block.Impl
-
Execute the given Block on the current thread.
- EXPAND - Static variable in class com.rpl.rama.ops.Ops
-
Emits every element of input list as a separate field.
- EXPLODE - Static variable in class com.rpl.rama.ops.Ops
-
Emits every element of input list individually.
- EXPLODE_INDEXED - Static variable in class com.rpl.rama.ops.Ops
-
Emits every element of input list individually along with index of emit.
- EXPLODE_MAP - Static variable in class com.rpl.rama.ops.Ops
-
Emits every key/value pair of input map individually.
- explodeMaterialized(String) - Static method in interface com.rpl.rama.Block
-
Emits all tuples across all partitions of a temporary PState created from
Block.materialize(java.lang.Object...)
. - explodeMaterialized(String) - Method in interface com.rpl.rama.Block.Impl
-
Emits all tuples across all partitions of a temporary PState created from
Block.materialize(java.lang.Object...)
. - explodeMaterialized(String) - Method in interface com.rpl.rama.Case.Impl
-
Emits all tuples across all partitions of a temporary PState created from
Block.materialize(java.lang.Object...)
. - explodeMaterialized(String) - Method in interface com.rpl.rama.SubSource.Impl
-
Emits all tuples across all partitions of a temporary PState created from
Block.materialize(java.lang.Object...)
. - explodeMicrobatch(String) - Static method in interface com.rpl.rama.Block
-
Emits all data for this microbatch source across all partitions of depot
- explodeMicrobatch(String) - Method in interface com.rpl.rama.Block.Impl
-
Emits all data for this microbatch source across all partitions of depot
- explodeMicrobatch(String) - Method in interface com.rpl.rama.Case.Impl
-
Emits all data for this microbatch source across all partitions of depot
- explodeMicrobatch(String) - Method in interface com.rpl.rama.SubSource.Impl
-
Emits all data for this microbatch source across all partitions of depot
- Expr - Class in com.rpl.rama
-
Specifies an expression to be used in an argument position in dataflow code.
- Expr(NativeAnyArityRamaOperation, Object...) - Constructor for class com.rpl.rama.Expr
-
Constructs an expression for built-in operation that takes any number of arguments
- Expr(RamaFunction0<R>) - Constructor for class com.rpl.rama.Expr
-
Constructs an expression with zero arguments
- Expr(RamaFunction1<T0, R>, Object) - Constructor for class com.rpl.rama.Expr
-
Constructs an expression with one argument
- Expr(RamaFunction2<T0, T1, R>, Object, Object) - Constructor for class com.rpl.rama.Expr
-
Constructs an expression with two arguments
- Expr(RamaFunction3<T0, T1, T2, R>, Object, Object, Object) - Constructor for class com.rpl.rama.Expr
-
Constructs an expression with three arguments
- Expr(RamaFunction4<T0, T1, T2, T3, R>, Object, Object, Object, Object) - Constructor for class com.rpl.rama.Expr
-
Constructs an expression with four arguments
- Expr(RamaFunction5<T0, T1, T2, T3, T4, R>, Object, Object, Object, Object, Object) - Constructor for class com.rpl.rama.Expr
-
Constructs an expression with five arguments
- Expr(RamaFunction6<T0, T1, T2, T3, T4, T5, R>, Object, Object, Object, Object, Object, Object) - Constructor for class com.rpl.rama.Expr
-
Constructs an expression with six arguments
- Expr(RamaFunction7<T0, T1, T2, T3, T4, T5, T6, R>, Object, Object, Object, Object, Object, Object, Object) - Constructor for class com.rpl.rama.Expr
-
Constructs an expression with seven arguments
- Expr(RamaFunction8<T0, T1, T2, T3, T4, T5, T6, T7, R>, Object, Object, Object, Object, Object, Object, Object, Object) - Constructor for class com.rpl.rama.Expr
-
Constructs an expression with eight arguments
- ExternalDepot - Interface in com.rpl.rama.integration
-
This interface is used to integrate external queue systems as depots inside Rama.
- EXTRACT_VALUE - Static variable in class com.rpl.rama.ops.Ops
-
Extracts contents of a PState as a value.
F
- fetchFrom(int, long) - Method in interface com.rpl.rama.integration.ExternalDepot
-
Asynchronously returns a chunk of records starting at the given offset.
- fetchFrom(int, long, long) - Method in interface com.rpl.rama.integration.ExternalDepot
-
Asynchronously returns the sequence of records between the given range of offsets.
- filteredList(Path) - Static method in interface com.rpl.rama.Path
-
Navigates to sublist of elements filtered based on given Path.
- filteredList(Path) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to sublist of elements filtered based on given Path.
- filterEqual(Object) - Static method in interface com.rpl.rama.Path
-
Continues navigation if current value is equal to provided value.
- filterEqual(Object) - Method in interface com.rpl.rama.Path.Impl
-
Continues navigation if current value is equal to provided value.
- filterGreaterThan(Object) - Static method in interface com.rpl.rama.Path
-
Continues navigation if current value is greater than provided value.
- filterGreaterThan(Object) - Method in interface com.rpl.rama.Path.Impl
-
Continues navigation if current value is greater than provided value.
- filterGreaterThanOrEqual(Object) - Static method in interface com.rpl.rama.Path
-
Continues navigation if current value is greater than or equal to provided value.
- filterGreaterThanOrEqual(Object) - Method in interface com.rpl.rama.Path.Impl
-
Continues navigation if current value is greater than or equal to provided value.
- filterLessThan(Object) - Static method in interface com.rpl.rama.Path
-
Continues navigation if current value is less than provided value.
- filterLessThan(Object) - Method in interface com.rpl.rama.Path.Impl
-
Continues navigation if current value is less than provided value.
- filterLessThanOrEqual(Object) - Static method in interface com.rpl.rama.Path
-
Continues navigation if current value is less than or equal to provided value.
- filterLessThanOrEqual(Object) - Method in interface com.rpl.rama.Path.Impl
-
Continues navigation if current value is less than or equal to provided value.
- filterNotEqual(Object) - Static method in interface com.rpl.rama.Path
-
Continues navigation if current value is not equal to provided value.
- filterNotEqual(Object) - Method in interface com.rpl.rama.Path.Impl
-
Continues navigation if current value is not equal to provided value.
- filterNotSelected(Path) - Static method in interface com.rpl.rama.Path
-
Continues navigation if provided path executed on current value navigates to zero values.
- filterNotSelected(Path) - Method in interface com.rpl.rama.Path.Impl
-
Continues navigation if provided path executed on current value navigates to zero values.
- filterPred(RamaFunction1<T0, R0>) - Static method in interface com.rpl.rama.Path
-
Continues navigation if provided function returns true on current value.
- filterPred(RamaFunction1<T0, R0>) - Method in interface com.rpl.rama.Path.Impl
-
Continues navigation if provided function returns true on current value.
- filterSelected(Path) - Static method in interface com.rpl.rama.Path
-
Continues navigation if provided path executed on current value navigates to at least one value.
- filterSelected(Path) - Method in interface com.rpl.rama.Path.Impl
-
Continues navigation if provided path executed on current value navigates to at least one value.
- first() - Static method in interface com.rpl.rama.Path
-
Navigates on list to first element if not empty.
- first() - Method in interface com.rpl.rama.Path.Impl
-
Navigates on list to first element if not empty.
- first(Object) - Static method in interface com.rpl.rama.Agg
-
Aggregates input to the first input seen
- FIRST - Static variable in class com.rpl.rama.ops.Ops
-
Emits first element of input collection or
null
if it is empty. - fixedKeysSchema(Object...) - Static method in interface com.rpl.rama.PState
-
Declare schema for map with different schema for each key.
- freshBatchSource() - Static method in interface com.rpl.rama.Block
-
Declares a new batch source within pre-agg portion of a
batch block
- freshBatchSource() - Method in interface com.rpl.rama.Block.Impl
-
Declares a new batch source within pre-agg portion of a
batch block
- freshBatchSource() - Method in interface com.rpl.rama.Case.Impl
-
Declares a new batch source within pre-agg portion of a
batch block
- freshBatchSource() - Method in interface com.rpl.rama.SubSource.Impl
-
Declares a new batch source within pre-agg portion of a
batch block
G
- gainedLeadership() - Method in interface com.rpl.rama.integration.TaskGlobalObject
-
This function is called on this object whenever the task on which it lives gains leadership.
- genHashingIndexKeys(int) - Static method in class com.rpl.rama.Helpers
-
Generates a key that hashes to each task in a range of tasks.
- genHashingIndexKeys(String, int) - Static method in class com.rpl.rama.Helpers
-
Generates a key starting with the given prefix that hashes to each task in a range of tasks.
- genPStateVar() - Static method in class com.rpl.rama.Helpers
-
Generates a unique PState var
- genPStateVar(String) - Static method in class com.rpl.rama.Helpers
-
Generates a unique PState var with the given prefix
- genVar() - Static method in class com.rpl.rama.Helpers
-
Generates a unique var
- genVar(String) - Static method in class com.rpl.rama.Helpers
-
Generates a unique var with the given prefix
- get() - Method in interface com.rpl.rama.ProxyState
-
Get current value of this object.
- GET - Static variable in class com.rpl.rama.ops.Ops
-
Arguments are a collection and a key and emits the value for the key in the collection.
- getAllowYield() - Method in class com.rpl.rama.SelectOptions.CaptureSelectOptions
- getAmt() - Method in class com.rpl.rama.diffs.SequenceIndexRemoveDiff
-
Number of removed elements
- getArgs() - Method in class com.rpl.rama.Expr
- getBeforeIndex() - Method in class com.rpl.rama.diffs.SequenceInsertDiff
-
Index where element was inserted
- getBeforeIndex() - Method in class com.rpl.rama.diffs.SequenceInsertsDiff
-
Index where elements were inserted
- getBlock() - Method in class com.rpl.rama.SubBatch
- getClusterRetriever() - Method in interface com.rpl.rama.integration.TaskGlobalContext
-
Returns ClusterManagerBase instance for retrieving foreign clients.
- getDeployedModuleNames() - Method in interface com.rpl.rama.cluster.ClusterManagerBase
-
Retrieves set of the names of all deployed modules on this cluster.
- getDiffs() - Method in class com.rpl.rama.diffs.MultiDiff
-
Diffs in the order in which they happened
- getElem() - Method in class com.rpl.rama.diffs.MultiSetAddDiff
-
Value added to multi-set
- getElem() - Method in class com.rpl.rama.diffs.MultiSetRemoveDiff
-
Value removed to multi-set
- getElem() - Method in class com.rpl.rama.diffs.SequenceInsertDiff
-
Inserted value
- getElem() - Method in class com.rpl.rama.diffs.SetAddDiff
-
Value of object added to set
- getElem() - Method in class com.rpl.rama.diffs.SetRemoveDiff
-
Value of object removed from set
- getElems() - Method in class com.rpl.rama.diffs.SequenceInsertsDiff
-
Inserted elements
- getEmits() - Method in class com.rpl.rama.test.MockOutputCollector
-
Retrieve captured emits in the order in which they happened
- getEmitsByStream() - Method in class com.rpl.rama.test.MockOutputCollector
-
Retrieve captured emits split by stream name.
- getEndOffset() - Method in class com.rpl.rama.MicrobatchParams
- getEndOffset() - Method in class com.rpl.rama.object.DepotPartitionInfo
-
Retrieves the end offset of the depot partition log.
- getFrequencyMillis() - Method in interface com.rpl.rama.integration.TaskGlobalObjectWithTick
-
Defines the frequency at which
TaskGlobalObjectWithTick.tick()
is called. - getFromIndex() - Method in class com.rpl.rama.diffs.SequenceChangeDiff
-
Sequence changed for every index after this index
- getFromIndex() - Method in class com.rpl.rama.diffs.SequenceReorderDiff
-
Index of element before move
- getFromKey() - Method in class com.rpl.rama.diffs.KeyChangeDiff
-
Original value of key
- getGeneratedVarPrefix(String) - Static method in class com.rpl.rama.Helpers
-
Gets prefix string used to generate a var
- getIndex() - Method in class com.rpl.rama.diffs.AppendDiff
-
Index of append, same as size of sequence before the append
- getIndex() - Method in class com.rpl.rama.diffs.SequenceIndexChangeDiff
-
Index of changed value
- getIndex() - Method in class com.rpl.rama.diffs.SequenceIndexRemoveDiff
-
Starting index where elements were removed
- getIndexToDiff() - Method in class com.rpl.rama.diffs.SequenceIndexChangesDiff
-
Map of index to diffs for their changed values
- getKey() - Method in class com.rpl.rama.diffs.KeyDiff
-
Key of changed value
- getKey() - Method in class com.rpl.rama.diffs.KeyRemoveDiff
-
Removed key
- getKeys() - Method in class com.rpl.rama.diffs.KeysRemoveDiff
-
Removed keys
- getKeyToDiff() - Method in class com.rpl.rama.diffs.KeysDiff
-
Map of keys to diffs for their values
- getLogThrottler() - Method in interface com.rpl.rama.integration.TaskGlobalContext
-
Return a log throttler instance for the current context.
- getMaxAmt() - Method in class com.rpl.rama.SortedRangeFromOptions.CapturedSortedRangeFromOptions
- getMaxAmt() - Method in class com.rpl.rama.SortedRangeToOptions.CapturedSortedRangeToOptions
- getMicrobatchDepotInfo(String, String) - Method in interface com.rpl.rama.cluster.ClusterManagerBase
-
Retrieve information about a microbatch topology's latest processed offsets for all depots depended on by the topology.
- getModuleInstanceId() - Method in class com.rpl.rama.ModuleInstanceInfo
-
Returns module instance ID
- getModuleInstanceInfo() - Method in interface com.rpl.rama.integration.TaskGlobalContext
-
Returns information about current module.
- getModuleName() - Method in class com.rpl.rama.ModuleInstanceInfo
-
Returns name of module
- getModuleName() - Method in class com.rpl.rama.object.PartitionedObjectInfo
-
Get the name of the module that the object belongs to.
- getModuleName() - Method in interface com.rpl.rama.RamaModule
-
Optional method to override the name of the module.
- getModuleStatus(String) - Method in interface com.rpl.rama.RamaClusterManager
-
Get status of a launched module
- getName() - Method in class com.rpl.rama.object.PartitionedObjectInfo
-
Get the name of the partitioned object.
- getNewCount() - Method in class com.rpl.rama.diffs.MultiSetAddDiff
-
Number of times element appears after adding it
- getNewCount() - Method in class com.rpl.rama.diffs.MultiSetRemoveDiff
-
Number of times element appears after removing it
- getNewSize() - Method in class com.rpl.rama.diffs.SequenceChangeDiff
-
Size of sequence after change
- getNumPartitions() - Method in interface com.rpl.rama.integration.ExternalDepot
-
Asynchronously returns the number of partitions in the external queue.
- getNumPartitions() - Method in class com.rpl.rama.object.PartitionedObjectInfo
-
Get the number of partitions of the partitioned object.
- getNumTasks() - Method in class com.rpl.rama.ModuleInstanceInfo
-
Returns number of tasks in module
- getNumTasks() - Method in class com.rpl.rama.test.LaunchConfig
- getNumThreads() - Method in class com.rpl.rama.test.LaunchConfig
- getNumWorkers() - Method in class com.rpl.rama.test.LaunchConfig
- getObject(String) - Method in interface com.rpl.rama.backup.BackupProvider
-
Get the contents of the key stored in the backup provider.
- getObjectInfo() - Method in interface com.rpl.rama.PartitionedObject
-
Retrieves information about the partitioned object - the name of the object, the module name, the number of partitions.
- getOldCount() - Method in class com.rpl.rama.diffs.MultiSetAddDiff
-
Number of times element appears before adding it
- getOldCount() - Method in class com.rpl.rama.diffs.MultiSetRemoveDiff
-
Number of times element appears before removing it
- getOldSize() - Method in class com.rpl.rama.diffs.SequenceChangeDiff
-
Size of sequence before change
- getOldSize() - Method in class com.rpl.rama.diffs.SequenceIndexRemoveDiff
-
Size of sequence before removes
- getOldSize() - Method in class com.rpl.rama.diffs.SequenceInsertDiff
-
Size of sequence before the insert
- getOldSize() - Method in class com.rpl.rama.diffs.SequenceInsertsDiff
-
Size of sequence before inserts
- getOp() - Method in class com.rpl.rama.Expr
- getOutputs() - Method in class com.rpl.rama.SubBatch
- getPartitionInfo(long) - Method in interface com.rpl.rama.Depot
-
Retrieves the start and end offsets of the log for the specified partition index of the depot.
- getPartitionInfoAsync(long) - Method in interface com.rpl.rama.Depot
-
Retrieves the start and end offsets of the log for the specified partition index of the depot.
- getPort() - Method in class com.rpl.rama.ModuleInstanceInfo
-
Returns port of worker where
ModuleInstanceInfo
was fetched - getReplicaId() - Method in interface com.rpl.rama.integration.TaskGlobalContext
-
Returns replica ID of this task thread.
- getReplicationFactor() - Method in class com.rpl.rama.ModuleInstanceInfo
-
Returns replication factor of module
- getResource() - Method in class com.rpl.rama.integration.ManagedResource
-
Constructs the resource using the provided constructor if it doesn't yet exist in the resource map
- getSequenceSize() - Method in class com.rpl.rama.diffs.SequenceReorderDiff
-
Size of sequence
- getStartOffset() - Method in class com.rpl.rama.MicrobatchParams
- getStartOffset() - Method in class com.rpl.rama.object.DepotPartitionInfo
-
Retrieves the start offset of the depot partition log.
- getStreamName() - Method in class com.rpl.rama.test.MockOutputCollector.CapturedEmit
- getSupervisorId() - Method in class com.rpl.rama.ModuleInstanceInfo
-
Returns supervisor ID where
ModuleInstanceInfo
was fetched - getTaskGroup() - Method in interface com.rpl.rama.integration.TaskGlobalContext
-
Returns set of all task IDs in the task group where this task global is being prepared.
- getTaskThreadIds() - Method in class com.rpl.rama.ModuleInstanceInfo
-
Return lowest task ID for each task thread in the module.
- getThrowable() - Method in class com.rpl.rama.diffs.UngracefulTerminationDiff
-
Last exception leading to ungraceful termination
- getToIndex() - Method in class com.rpl.rama.diffs.SequenceReorderDiff
-
New index for element after move
- getToKey() - Method in class com.rpl.rama.diffs.KeyChangeDiff
-
New value of key
- getVal() - Method in class com.rpl.rama.diffs.NewValueDiff
-
New value of object
- getValDiff() - Method in class com.rpl.rama.diffs.KeyDiff
-
Diff of changed value
- getValDiff() - Method in class com.rpl.rama.diffs.SequenceIndexChangeDiff
-
Diff of changed value
- getValue() - Method in class com.rpl.rama.Constant
- getValues() - Method in class com.rpl.rama.test.MockOutputCollector.CapturedEmit
- getVarName() - Method in interface com.rpl.rama.integration.TaskGlobalContext
-
Returns the var name assigned to this object in the module definition.
- getVars() - Method in class com.rpl.rama.LoopVars.LoopVarsCollector
- global() - Method in interface com.rpl.rama.Depot.Declaration
-
Configures depot to have a single partition.
- global() - Method in interface com.rpl.rama.PState.Declaration
-
Configures PState to have a single partition.
- globalPartition() - Static method in interface com.rpl.rama.Block
-
Changes to task 0
- globalPartition() - Method in interface com.rpl.rama.Block.Impl
-
Changes to task 0
- globalPartition() - Method in interface com.rpl.rama.Case.Impl
-
Changes to task 0
- globalPartition() - Method in interface com.rpl.rama.SubSource.Impl
-
Changes to task 0
- globalPartition(String) - Static method in interface com.rpl.rama.Block
-
Changes to partition 0 of given depot or PState.
- globalPartition(String) - Method in interface com.rpl.rama.Block.Impl
-
Changes to partition 0 of given depot or PState.
- globalPartition(String) - Method in interface com.rpl.rama.Case.Impl
-
Changes to partition 0 of given depot or PState.
- globalPartition(String) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes to partition 0 of given depot or PState.
- GREATER_THAN - Static variable in class com.rpl.rama.ops.Ops
-
Emits boolean true or false on if each argument is greater than the next argument.
- GREATER_THAN_OR_EQUAL - Static variable in class com.rpl.rama.ops.Ops
-
Emits boolean true or false on if each argument is greater than or equal to the next argument.
- groupBy(String, Block) - Static method in interface com.rpl.rama.Block
-
Groups input by one key and performs aggregations in the specified block on each group of data independently.
- groupBy(String, Block) - Method in interface com.rpl.rama.Block.Impl
-
Groups input by one key and performs aggregations in the specified block on each group of data independently.
- groupBy(String, Block) - Method in interface com.rpl.rama.Case.Impl
-
Groups input by one key and performs aggregations in the specified block on each group of data independently.
- groupBy(String, Block) - Method in interface com.rpl.rama.SubSource.Impl
-
Groups input by one key and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, Block) - Static method in interface com.rpl.rama.Block
-
Groups input by two keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, Block) - Method in interface com.rpl.rama.Block.Impl
-
Groups input by two keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, Block) - Method in interface com.rpl.rama.Case.Impl
-
Groups input by two keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, Block) - Method in interface com.rpl.rama.SubSource.Impl
-
Groups input by two keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, String, Block) - Static method in interface com.rpl.rama.Block
-
Groups input by three keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, String, Block) - Method in interface com.rpl.rama.Block.Impl
-
Groups input by three keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, String, Block) - Method in interface com.rpl.rama.Case.Impl
-
Groups input by three keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, String, Block) - Method in interface com.rpl.rama.SubSource.Impl
-
Groups input by three keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, String, String, Block) - Static method in interface com.rpl.rama.Block
-
Groups input by four keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, String, String, Block) - Method in interface com.rpl.rama.Block.Impl
-
Groups input by four keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, String, String, Block) - Method in interface com.rpl.rama.Case.Impl
-
Groups input by four keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, String, String, Block) - Method in interface com.rpl.rama.SubSource.Impl
-
Groups input by four keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, String, String, String, Block) - Static method in interface com.rpl.rama.Block
-
Groups input by five keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, String, String, String, Block) - Method in interface com.rpl.rama.Block.Impl
-
Groups input by five keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, String, String, String, Block) - Method in interface com.rpl.rama.Case.Impl
-
Groups input by five keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, String, String, String, Block) - Method in interface com.rpl.rama.SubSource.Impl
-
Groups input by five keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, String, String, String, String, Block) - Static method in interface com.rpl.rama.Block
-
Groups input by six keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, String, String, String, String, Block) - Method in interface com.rpl.rama.Block.Impl
-
Groups input by six keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, String, String, String, String, Block) - Method in interface com.rpl.rama.Case.Impl
-
Groups input by six keys and performs aggregations in the specified block on each group of data independently.
- groupBy(String, String, String, String, String, String, Block) - Method in interface com.rpl.rama.SubSource.Impl
-
Groups input by six keys and performs aggregations in the specified block on each group of data independently.
H
- hashBy(NativeRamaFunction1) - Static method in interface com.rpl.rama.Depot
-
Depot partitioning based on hashing a value from the data being appended.
- hashBy(Class<T>) - Static method in interface com.rpl.rama.Depot
-
Depot partitioning based on hashing a value from the data being appended.
- hashBy(String) - Static method in interface com.rpl.rama.Depot
-
Depot partitioning based on hashing a value from the data being appended.
- hashCode() - Method in class com.rpl.rama.diffs.AppendDiff
- hashCode() - Method in class com.rpl.rama.diffs.DestroyedDiff
- hashCode() - Method in class com.rpl.rama.diffs.KeyChangeDiff
- hashCode() - Method in class com.rpl.rama.diffs.KeyDiff
- hashCode() - Method in class com.rpl.rama.diffs.KeyRemoveDiff
- hashCode() - Method in class com.rpl.rama.diffs.KeysDiff
- hashCode() - Method in class com.rpl.rama.diffs.KeysRemoveDiff
- hashCode() - Method in class com.rpl.rama.diffs.MultiDiff
- hashCode() - Method in class com.rpl.rama.diffs.MultiSetAddDiff
- hashCode() - Method in class com.rpl.rama.diffs.MultiSetRemoveDiff
- hashCode() - Method in class com.rpl.rama.diffs.NewValueDiff
- hashCode() - Method in class com.rpl.rama.diffs.ResyncDiff
- hashCode() - Method in class com.rpl.rama.diffs.SequenceChangeDiff
- hashCode() - Method in class com.rpl.rama.diffs.SequenceIndexChangeDiff
- hashCode() - Method in class com.rpl.rama.diffs.SequenceIndexChangesDiff
- hashCode() - Method in class com.rpl.rama.diffs.SequenceIndexRemoveDiff
- hashCode() - Method in class com.rpl.rama.diffs.SequenceInsertDiff
- hashCode() - Method in class com.rpl.rama.diffs.SequenceInsertsDiff
- hashCode() - Method in class com.rpl.rama.diffs.SequenceReorderDiff
- hashCode() - Method in class com.rpl.rama.diffs.SetAddDiff
- hashCode() - Method in class com.rpl.rama.diffs.SetRemoveDiff
- hashCode() - Method in class com.rpl.rama.diffs.UngracefulTerminationDiff
- hashCode() - Method in class com.rpl.rama.diffs.UnknownDiff
- hashPartition(Object) - Static method in interface com.rpl.rama.Block
-
Changes tasks based on hash of argument modulo number of tasks in module.
- hashPartition(Object) - Method in interface com.rpl.rama.Block.Impl
-
Changes tasks based on hash of argument modulo number of tasks in module.
- hashPartition(Object) - Method in interface com.rpl.rama.Case.Impl
-
Changes tasks based on hash of argument modulo number of tasks in module.
- hashPartition(Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes tasks based on hash of argument modulo number of tasks in module.
- hashPartition(String, Object) - Static method in interface com.rpl.rama.Block
-
Changes tasks based on hash of argument modulo number of partitions of given depot or PState.
- hashPartition(String, Object) - Method in interface com.rpl.rama.Block.Impl
-
Changes tasks based on hash of argument modulo number of partitions of given depot or PState.
- hashPartition(String, Object) - Method in interface com.rpl.rama.Case.Impl
-
Changes tasks based on hash of argument modulo number of partitions of given depot or PState.
- hashPartition(String, Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes tasks based on hash of argument modulo number of partitions of given depot or PState.
- hasKey(String) - Method in interface com.rpl.rama.backup.BackupProvider
-
Predicate for key existing in the provider.
- Helpers - Class in com.rpl.rama
-
Collection of static utility methods
- Helpers() - Constructor for class com.rpl.rama.Helpers
- hook(String) - Static method in interface com.rpl.rama.Block
-
Changes attachment point for subsequent code to node with given anchor
- hook(String) - Method in interface com.rpl.rama.Block.Impl
-
Changes attachment point for subsequent code to node with given anchor
- hook(String) - Method in interface com.rpl.rama.Case.Impl
-
Changes attachment point for subsequent code to node with given anchor
- hook(String) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes attachment point for subsequent code to node with given anchor
- HOURS - Enum constant in enum class com.rpl.rama.module.OffsetAgo
-
Start from first record added after this many hours in the past
I
- IDENTITY - Static variable in class com.rpl.rama.ops.Ops
-
Emits input argument
- idFunction(RamaFunction1<T, R>) - Method in interface com.rpl.rama.ops.TopMonotonicAgg
-
Function to extract ID from data to de-duplicate results
- idTuple(TaskGlobalContext) - Method in class com.rpl.rama.integration.ManagedResource
- idTuple(TaskGlobalContext) - Method in class com.rpl.rama.integration.TaskThreadManagedResource
- idTuple(TaskGlobalContext) - Method in class com.rpl.rama.integration.WorkerManagedResource
- ifPath(Path, Path) - Static method in interface com.rpl.rama.Path
-
Tests condition against current point and continues navigating with
thenPath
if condition passes. - ifPath(Path, Path) - Method in interface com.rpl.rama.Path.Impl
-
Tests condition against current point and continues navigating with
thenPath
if condition passes. - ifPath(Path, Path, Path) - Static method in interface com.rpl.rama.Path
-
Tests condition against current point and continues navigating with
thenPath
if condition passes. - ifPath(Path, Path, Path) - Method in interface com.rpl.rama.Path.Impl
-
Tests condition against current point and continues navigating with
thenPath
if condition passes. - ifTrue(Object, Block) - Static method in interface com.rpl.rama.Block
-
If argument is truthy (not null or boolean false), runs thenBlock.
- ifTrue(Object, Block) - Method in interface com.rpl.rama.Block.Impl
-
If argument is truthy (not null or boolean false), runs thenBlock.
- ifTrue(Object, Block) - Method in interface com.rpl.rama.Case.Impl
-
If argument is truthy (not null or boolean false), runs thenBlock.
- ifTrue(Object, Block) - Method in interface com.rpl.rama.SubSource.Impl
-
If argument is truthy (not null or boolean false), runs thenBlock.
- ifTrue(Object, Block, Block) - Static method in interface com.rpl.rama.Block
-
If argument is truthy (not null or boolean false), runs thenBlock – otherwise, runs elseBlock.
- ifTrue(Object, Block, Block) - Method in interface com.rpl.rama.Block.Impl
-
If argument is truthy (not null or boolean false), runs thenBlock – otherwise, runs elseBlock.
- ifTrue(Object, Block, Block) - Method in interface com.rpl.rama.Case.Impl
-
If argument is truthy (not null or boolean false), runs thenBlock – otherwise, runs elseBlock.
- ifTrue(Object, Block, Block) - Method in interface com.rpl.rama.SubSource.Impl
-
If argument is truthy (not null or boolean false), runs thenBlock – otherwise, runs elseBlock.
- INC - Static variable in class com.rpl.rama.ops.Ops
-
Emits one more than input value as an
Integer
- INC_LONG - Static variable in class com.rpl.rama.ops.Ops
-
Emits one more than input value as a
Long
- includeEnd() - Method in class com.rpl.rama.SortedRangeOptions.CapturedSortedRangeOptions
- includeEnd() - Method in interface com.rpl.rama.SortedRangeOptions.Impl
-
Includes the end key in the results (by default it's excluded).
- includeEnd() - Static method in interface com.rpl.rama.SortedRangeOptions
-
Includes the end key in the results (by default it's excluded).
- includeEnd() - Method in class com.rpl.rama.SortedRangeToOptions.CapturedSortedRangeToOptions
- includeEnd() - Method in interface com.rpl.rama.SortedRangeToOptions.Impl
-
Includes the end key in the results (by default it's excluded).
- includeEnd() - Static method in interface com.rpl.rama.SortedRangeToOptions
-
Includes the end key in the results (by default it's excluded).
- index(Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to the index of a list if it exists.
- index(Object) - Static method in interface com.rpl.rama.Path
-
Navigates to the index of a list if it exists.
- indexedVals() - Method in interface com.rpl.rama.Path.Impl
-
Navigates to pairs of
[index, value]
for every element of list. - indexedVals() - Static method in interface com.rpl.rama.Path
-
Navigates to pairs of
[index, value]
for every element of list. - indexVar(String) - Method in interface com.rpl.rama.ops.LimitAgg
-
If set also emits the index of each emit to the specified var
- init - Variable in class com.rpl.rama.LoopVars.LoopVar
- initialValue(Object) - Method in interface com.rpl.rama.PState.Declaration
-
Specifies starting value for PState.
- initVal() - Method in interface com.rpl.rama.ops.RamaAccumulatorAgg
-
Initial value for aggregation
- InProcessCluster - Interface in com.rpl.rama.test
-
Simulates a Rama cluster in a single process.
- invoke() - Method in interface com.rpl.rama.ops.RamaFunction0
-
Computes result of function from input arguments
- invoke(OutputCollector) - Method in interface com.rpl.rama.ops.RamaOperation0
-
Executes operation and emits results by calling methods on the provided
OutputCollector
- invoke(Object...) - Method in interface com.rpl.rama.QueryTopologyClient
-
Blocking invoke.
- invoke(T0) - Method in interface com.rpl.rama.ops.RamaFunction1
-
Computes result of function from input arguments
- invoke(T0, OutputCollector) - Method in interface com.rpl.rama.ops.RamaOperation1
-
Executes operation and emits results by calling methods on the provided
OutputCollector
- invoke(T0, T1) - Method in interface com.rpl.rama.ops.RamaFunction2
-
Computes result of function from input arguments
- invoke(T0, T1, OutputCollector) - Method in interface com.rpl.rama.ops.RamaOperation2
-
Executes operation and emits results by calling methods on the provided
OutputCollector
- invoke(T0, T1, T2) - Method in interface com.rpl.rama.ops.RamaFunction3
-
Computes result of function from input arguments
- invoke(T0, T1, T2, OutputCollector) - Method in interface com.rpl.rama.ops.RamaOperation3
-
Executes operation and emits results by calling methods on the provided
OutputCollector
- invoke(T0, T1, T2, T3) - Method in interface com.rpl.rama.ops.RamaFunction4
-
Computes result of function from input arguments
- invoke(T0, T1, T2, T3, OutputCollector) - Method in interface com.rpl.rama.ops.RamaOperation4
-
Executes operation and emits results by calling methods on the provided
OutputCollector
- invoke(T0, T1, T2, T3, T4) - Method in interface com.rpl.rama.ops.RamaFunction5
-
Computes result of function from input arguments
- invoke(T0, T1, T2, T3, T4, OutputCollector) - Method in interface com.rpl.rama.ops.RamaOperation5
-
Executes operation and emits results by calling methods on the provided
OutputCollector
- invoke(T0, T1, T2, T3, T4, T5) - Method in interface com.rpl.rama.ops.RamaFunction6
-
Computes result of function from input arguments
- invoke(T0, T1, T2, T3, T4, T5, OutputCollector) - Method in interface com.rpl.rama.ops.RamaOperation6
-
Executes operation and emits results by calling methods on the provided
OutputCollector
- invoke(T0, T1, T2, T3, T4, T5, T6) - Method in interface com.rpl.rama.ops.RamaFunction7
-
Computes result of function from input arguments
- invoke(T0, T1, T2, T3, T4, T5, T6, OutputCollector) - Method in interface com.rpl.rama.ops.RamaOperation7
-
Executes operation and emits results by calling methods on the provided
OutputCollector
- invoke(T0, T1, T2, T3, T4, T5, T6, T7) - Method in interface com.rpl.rama.ops.RamaFunction8
-
Computes result of function from input arguments
- invoke(T0, T1, T2, T3, T4, T5, T6, T7, OutputCollector) - Method in interface com.rpl.rama.ops.RamaOperation8
-
Executes operation and emits results by calling methods on the provided
OutputCollector
- invokeAsync(Object...) - Method in interface com.rpl.rama.QueryTopologyClient
-
Non-blocking invoke.
- invokeNext(Object) - Method in interface com.rpl.rama.Navigator.Next
- invokeQuery(String, Object...) - Method in interface com.rpl.rama.Block.Impl
-
Invokes a colocated or mirror query topology
- invokeQuery(String, Object...) - Static method in interface com.rpl.rama.Block
-
Invokes a colocated or mirror query topology
- invokeQuery(String, Object...) - Method in interface com.rpl.rama.Case.Impl
-
Invokes a colocated or mirror query topology
- invokeQuery(String, Object...) - Method in interface com.rpl.rama.SubSource.Impl
-
Invokes a colocated or mirror query topology
- IS_EVEN - Static variable in class com.rpl.rama.ops.Ops
-
Emits boolean true or false on whether input argument is an even number
- IS_INSTANCE_OF - Static variable in class com.rpl.rama.ops.Ops
-
Arguments are a
Class
and object and emits boolean true or false on whether the second argument is an instance of the first argument - IS_NEGATIVE - Static variable in class com.rpl.rama.ops.Ops
-
Emits boolean true or false on whether input argument is a negative number
- IS_NOT_NULL - Static variable in class com.rpl.rama.ops.Ops
-
Emits boolean true or false on whether input argument is not
null
- IS_NULL - Static variable in class com.rpl.rama.ops.Ops
-
Emits boolean true or false on whether input argument is
null
- IS_NUMBER - Static variable in class com.rpl.rama.ops.Ops
-
Emits boolean true or false on whether input argument is a number
- IS_ODD - Static variable in class com.rpl.rama.ops.Ops
-
Emits boolean true or false on whether input argument is an odd number
- IS_POSITIVE - Static variable in class com.rpl.rama.ops.Ops
-
Emits boolean true or false on whether input argument is a positive number
- isCollected(RamaFunction1<T0, R0>) - Method in interface com.rpl.rama.Path.Impl
-
Stops navigation if given function on collected values returns false.
- isCollected(RamaFunction1<T0, R0>) - Static method in interface com.rpl.rama.Path
-
Stops navigation if given function on collected values returns false.
- isEndIncluded() - Method in class com.rpl.rama.SortedRangeOptions.CapturedSortedRangeOptions
- isEndIncluded() - Method in class com.rpl.rama.SortedRangeToOptions.CapturedSortedRangeToOptions
- isFlushRequired() - Method in interface com.rpl.rama.ops.RamaCombinerAgg
-
Controls memory usage when Rama performs two-phase optimization for combiners.
- isGeneratedVar(String) - Static method in class com.rpl.rama.Helpers
-
Tests if a string has the format of a regular var or PState var
- isSizeTracked() - Method in class com.rpl.rama.SubindexOptions.CapturedSubindexOptions
- isStartIncluded() - Method in class com.rpl.rama.SortedRangeFromOptions.CapturedSortedRangeFromOptions
- isStartIncluded() - Method in class com.rpl.rama.SortedRangeOptions.CapturedSortedRangeOptions
K
- keepTrue(Object) - Method in interface com.rpl.rama.Block.Impl
-
Continues dataflow execution only if arg is truthy (not null or boolean false).
- keepTrue(Object) - Static method in interface com.rpl.rama.Block
-
Continues dataflow execution only if arg is truthy (not null or boolean false).
- keepTrue(Object) - Method in interface com.rpl.rama.Case.Impl
-
Continues dataflow execution only if arg is truthy (not null or boolean false).
- keepTrue(Object) - Method in interface com.rpl.rama.SubSource.Impl
-
Continues dataflow execution only if arg is truthy (not null or boolean false).
- key(Object...) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to value for a key in a map.
- key(Object...) - Static method in interface com.rpl.rama.Path
-
Navigates to value for a key in a map.
- KeyChangeDiff - Class in com.rpl.rama.diffs
-
Represents a key in a map changing to a new value.
- KeyChangeDiff(Object, Object) - Constructor for class com.rpl.rama.diffs.KeyChangeDiff
- KeyChangeDiff.Processor - Interface in com.rpl.rama.diffs
- KeyDiff - Class in com.rpl.rama.diffs
-
Represents a value for a key changing.
- KeyDiff(Object, Diff) - Constructor for class com.rpl.rama.diffs.KeyDiff
- KeyDiff.Processor - Interface in com.rpl.rama.diffs
- keyPartitioner(Class<F>) - Method in interface com.rpl.rama.PState.Declaration
-
Changes the default key partitioner to a custom one.
- KeyRemoveDiff - Class in com.rpl.rama.diffs
-
Represents a key being removed from data structure.
- KeyRemoveDiff(Object) - Constructor for class com.rpl.rama.diffs.KeyRemoveDiff
- KeyRemoveDiff.Processor - Interface in com.rpl.rama.diffs
- keys - Variable in class com.rpl.rama.backup.BackupProvider.KeysPage
- KeysDiff - Class in com.rpl.rama.diffs
-
Represents changes for values for multiple keys in a data structure.
- KeysDiff(Map<Object, Diff>) - Constructor for class com.rpl.rama.diffs.KeysDiff
- KeysDiff.Processor - Interface in com.rpl.rama.diffs
- KeysPage(List<String>, String) - Constructor for class com.rpl.rama.backup.BackupProvider.KeysPage
- KeysRemoveDiff - Class in com.rpl.rama.diffs
-
Represents multiple keys being removed from map data structure.
- KeysRemoveDiff(Set<Object>) - Constructor for class com.rpl.rama.diffs.KeysRemoveDiff
- KeysRemoveDiff.Processor - Interface in com.rpl.rama.diffs
L
- last() - Method in interface com.rpl.rama.Path.Impl
-
Navigates on list to last element if not empty.
- last() - Static method in interface com.rpl.rama.Path
-
Navigates on list to last element if not empty.
- last(Object) - Static method in interface com.rpl.rama.Agg
-
Aggregates input to the last input seen
- LAST - Static variable in class com.rpl.rama.ops.Ops
-
Emits last element of input collection or
null
if it is empty. - LaunchConfig - Class in com.rpl.rama.test
-
Object to specify parallelism settings for modules launched on an
InProcessCluster
- LaunchConfig(int, int) - Constructor for class com.rpl.rama.test.LaunchConfig
-
Create LaunchConfig.
- launchModule(RamaModule, LaunchConfig) - Method in interface com.rpl.rama.test.InProcessCluster
-
Launch a module.
- LESS_THAN - Static variable in class com.rpl.rama.ops.Ops
-
Emits boolean true or false on if each argument is less than the next argument.
- LESS_THAN_OR_EQUAL - Static variable in class com.rpl.rama.ops.Ops
-
Emits boolean true or false on if each argument is less than or equal to the next argument.
- limitAgg(LimitAgg) - Method in interface com.rpl.rama.Block.Impl
-
Limits incoming data to a fixed amount according to optional sort options.
- limitAgg(LimitAgg) - Static method in interface com.rpl.rama.Block
-
Limits incoming data to a fixed amount according to optional sort options.
- limitAgg(LimitAgg) - Method in interface com.rpl.rama.Case.Impl
-
Limits incoming data to a fixed amount according to optional sort options.
- limitAgg(LimitAgg) - Method in interface com.rpl.rama.SubSource.Impl
-
Limits incoming data to a fixed amount according to optional sort options.
- LimitAgg - Interface in com.rpl.rama.ops
-
Specifies a limit aggregator for use with
limitAgg
- list(AggOrCompoundAgg...) - Static method in interface com.rpl.rama.CompoundAgg
-
Specifies a fixed-size list template
- list(Object) - Static method in interface com.rpl.rama.Agg
-
Aggregates all input to a java.util.List data structure.
- listKeysNonRecursive(String, String, int) - Method in interface com.rpl.rama.backup.BackupProvider
-
List all keys with the given prefix without recursing into sub-directories.
- listKeysRecursive(String, String) - Method in interface com.rpl.rama.backup.BackupProvider
-
List all keys with the given prefix.
- listSchema(PState.Schema) - Static method in interface com.rpl.rama.PState
-
Declare a list schema
- listSchema(Class) - Static method in interface com.rpl.rama.PState
-
Declare a list schema
- localClear(String) - Method in interface com.rpl.rama.Block.Impl
-
Removes all data from the PState partition on current task.
- localClear(String) - Static method in interface com.rpl.rama.Block
-
Removes all data from the PState partition on current task.
- localClear(String) - Method in interface com.rpl.rama.Case.Impl
-
Removes all data from the PState partition on current task.
- localClear(String) - Method in interface com.rpl.rama.SubSource.Impl
-
Removes all data from the PState partition on current task.
- localSelect(String, Path) - Method in interface com.rpl.rama.Block.Impl
-
Navigates into the PState partition on current task using the given
Path
. - localSelect(String, Path) - Static method in interface com.rpl.rama.Block
-
Navigates into the PState partition on current task using the given
Path
. - localSelect(String, Path) - Method in interface com.rpl.rama.Case.Impl
-
Navigates into the PState partition on current task using the given
Path
. - localSelect(String, Path) - Method in interface com.rpl.rama.SubSource.Impl
-
Navigates into the PState partition on current task using the given
Path
. - localSelect(String, Path, SelectOptions) - Method in interface com.rpl.rama.Block.Impl
-
Navigates into the PState partition on current task using the given
Path
. - localSelect(String, Path, SelectOptions) - Static method in interface com.rpl.rama.Block
-
Navigates into the PState partition on current task using the given
Path
. - localSelect(String, Path, SelectOptions) - Method in interface com.rpl.rama.Case.Impl
-
Navigates into the PState partition on current task using the given
Path
. - localSelect(String, Path, SelectOptions) - Method in interface com.rpl.rama.SubSource.Impl
-
Navigates into the PState partition on current task using the given
Path
. - localTransform(String, Path) - Method in interface com.rpl.rama.Block.Impl
-
Executes
transform Path
on the PState partition on current task. - localTransform(String, Path) - Static method in interface com.rpl.rama.Block
-
Executes
transform Path
on the PState partition on current task. - localTransform(String, Path) - Method in interface com.rpl.rama.Case.Impl
-
Executes
transform Path
on the PState partition on current task. - localTransform(String, Path) - Method in interface com.rpl.rama.SubSource.Impl
-
Executes
transform Path
on the PState partition on current task. - LOG_DEBUG - Static variable in class com.rpl.rama.ops.Ops
-
Logs at debug level using slf4j Logger.
- LOG_ERROR - Static variable in class com.rpl.rama.ops.Ops
-
Logs at error level using slf4j Logger.
- LOG_INFO - Static variable in class com.rpl.rama.ops.Ops
-
Logs at info level using slf4j Logger.
- LOG_TRACE - Static variable in class com.rpl.rama.ops.Ops
-
Logs at trace level using slf4j Logger.
- LOG_WARN - Static variable in class com.rpl.rama.ops.Ops
-
Logs at warn level using slf4j Logger.
- loop(Block) - Method in interface com.rpl.rama.Block.Impl
-
Creates a dataflow loop with the given body.
- loop(Block) - Static method in interface com.rpl.rama.Block
-
Creates a dataflow loop with the given body.
- loop(Block) - Method in interface com.rpl.rama.Case.Impl
-
Creates a dataflow loop with the given body.
- loop(Block) - Method in interface com.rpl.rama.SubSource.Impl
-
Creates a dataflow loop with the given body.
- LoopVar(String, Object) - Constructor for class com.rpl.rama.LoopVars.LoopVar
- LoopVars - Interface in com.rpl.rama
-
Declares vars for a
loopWithVars
call using builder pattern Example:LoopVars.var("*a", 1).var("*b", 2)
- LoopVars.Impl - Interface in com.rpl.rama
- LoopVars.LoopVar - Class in com.rpl.rama
- LoopVars.LoopVarsCollector - Class in com.rpl.rama
- LoopVarsCollector(PersistentVector) - Constructor for class com.rpl.rama.LoopVars.LoopVarsCollector
- loopWithVars(LoopVars, Block) - Method in interface com.rpl.rama.Block.Impl
-
Creates a dataflow loop with the given vars and body.
- loopWithVars(LoopVars, Block) - Static method in interface com.rpl.rama.Block
-
Creates a dataflow loop with the given vars and body.
- loopWithVars(LoopVars, Block) - Method in interface com.rpl.rama.Case.Impl
-
Creates a dataflow loop with the given vars and body.
- loopWithVars(LoopVars, Block) - Method in interface com.rpl.rama.SubSource.Impl
-
Creates a dataflow loop with the given vars and body.
M
- macro(Block) - Method in interface com.rpl.rama.Block.Impl
-
Inserts all code from given Block into the current callsite.
- macro(Block) - Static method in interface com.rpl.rama.Block
-
Inserts all code from given Block into the current callsite.
- macro(Block) - Method in interface com.rpl.rama.Case.Impl
-
Inserts all code from given Block into the current callsite.
- macro(Block) - Method in interface com.rpl.rama.SubSource.Impl
-
Inserts all code from given Block into the current callsite.
- makePrivate() - Method in interface com.rpl.rama.PState.Declaration
-
Configures PState to only be readable within the declaring topology.
- ManagedResource<T> - Class in com.rpl.rama.integration
- ManagedResource(String, TaskGlobalContext, Callable<T>) - Constructor for class com.rpl.rama.integration.ManagedResource
- map(Object...) - Static method in interface com.rpl.rama.CompoundAgg
-
Specifies a map template
- map(Object, Object) - Static method in interface com.rpl.rama.Agg
-
Aggregates all input to a java.util.Map data structure.
- mapKey(Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to a key in a map if it exists.
- mapKey(Object) - Static method in interface com.rpl.rama.Path
-
Navigates to a key in a map if it exists.
- mapKeys() - Method in interface com.rpl.rama.Path.Impl
-
Navigates to every key of a map.
- mapKeys() - Static method in interface com.rpl.rama.Path
-
Navigates to every key of a map.
- mapSchema(Class, PState.Schema) - Static method in interface com.rpl.rama.PState
-
Declare a map schema
- mapSchema(Class, Class) - Static method in interface com.rpl.rama.PState
-
Declare a map schema
- mapVals() - Method in interface com.rpl.rama.Path.Impl
-
Navigates to every value of a map.
- mapVals() - Static method in interface com.rpl.rama.Path
-
Navigates to every value of a map.
- materialize(Object...) - Method in interface com.rpl.rama.Block.Impl
-
Produces a temporary PState of tuples within a batch block in a microbatch topology.
- materialize(Object...) - Static method in interface com.rpl.rama.Block
-
Produces a temporary PState of tuples within a batch block in a microbatch topology.
- materialize(Object...) - Method in interface com.rpl.rama.Case.Impl
-
Produces a temporary PState of tuples within a batch block in a microbatch topology.
- materialize(Object...) - Method in interface com.rpl.rama.SubSource.Impl
-
Produces a temporary PState of tuples within a batch block in a microbatch topology.
- max(Object) - Static method in interface com.rpl.rama.Agg
-
Computes maximum value from input
- MAX - Static variable in class com.rpl.rama.ops.Ops
-
Emits maximum value of all input arguments
- maxAmt(int) - Method in class com.rpl.rama.SortedRangeFromOptions.CapturedSortedRangeFromOptions
- maxAmt(int) - Method in interface com.rpl.rama.SortedRangeFromOptions.Impl
-
Sets maximum number of elements to include in result (by default reads until the end of structure).
- maxAmt(int) - Static method in interface com.rpl.rama.SortedRangeFromOptions
-
Sets maximum number of elements to include in result (by default reads until the end of structure).
- maxAmt(int) - Method in class com.rpl.rama.SortedRangeToOptions.CapturedSortedRangeToOptions
- maxAmt(int) - Method in interface com.rpl.rama.SortedRangeToOptions.Impl
-
Sets maximum number of elements to include in result (by default reads until the end of structure).
- maxAmt(int) - Static method in interface com.rpl.rama.SortedRangeToOptions
-
Sets maximum number of elements to include in result (by default reads until the end of structure).
- mergeMap(Object) - Static method in interface com.rpl.rama.Agg
-
Aggregates input java.util.Maps together into a single java.util.Map by adding all key/value pairs of each input.
- microbatch(String) - Method in interface com.rpl.rama.RamaModule.Topologies
-
Defines a microbatch topology.
- MicrobatchParams - Class in com.rpl.rama
- MicrobatchParams(long, long) - Constructor for class com.rpl.rama.MicrobatchParams
- MicrobatchSourceOptions - Interface in com.rpl.rama.module
-
Depot source options for microbatch topologies using builder pattern Microbatch topologies documentation
- MicrobatchSourceOptions.Impl - Interface in com.rpl.rama.module
- MicrobatchTopology - Interface in com.rpl.rama.module
- migrated(Object, String, RamaFunction1<?, ?>) - Static method in interface com.rpl.rama.PState
-
Declares a migration at a location in a PState schema.
- migrateToSubindexed() - Method in interface com.rpl.rama.PState.MigratedSchema
-
Migration option to specify a value is being changed to a subindexed structure.
- migration(String, RamaFunction1<?, ?>) - Method in interface com.rpl.rama.Depot.Declaration
-
Specify a migration on this depot.
- min(Object) - Static method in interface com.rpl.rama.Agg
-
Computes minimum value from input
- MIN - Static variable in class com.rpl.rama.ops.Ops
-
Emits minimum value of all input arguments
- MINUS - Static variable in class com.rpl.rama.ops.Ops
-
Emits result of subtracting all arguments after the first argument from the first argument as an
Integer
. - MINUS_LONG - Static variable in class com.rpl.rama.ops.Ops
-
Emits result of subtracting all arguments after the first argument from the first argument as a
Long
. - MINUTES - Enum constant in enum class com.rpl.rama.module.OffsetAgo
-
Start from first record added after this many minutes in the past
- MockOutputCollector - Class in com.rpl.rama.test
-
Helper utility for unit testing a
RamaOperation
outside the context of a module orBlock
. - MockOutputCollector() - Constructor for class com.rpl.rama.test.MockOutputCollector
- MockOutputCollector.CapturedEmit - Class in com.rpl.rama.test
-
Information about a captured emit
- MODULE_INSTANCE_INFO - Static variable in class com.rpl.rama.ops.Ops
-
Emits
ModuleInstanceInfo
for module and worker of running event - ModuleInstanceInfo - Class in com.rpl.rama
-
Information about current module and worker retrievable during topology execution with
Ops.MODULE_INSTANCE_INFO
- ModuleInstanceInfo(String, String, int, int, String, int, Set<Integer>) - Constructor for class com.rpl.rama.ModuleInstanceInfo
- MODULO - Static variable in class com.rpl.rama.ops.Ops
-
Emits first argument modulo the second argument as an
Integer
- MODULO_LONG - Static variable in class com.rpl.rama.ops.Ops
-
Emits first argument modulo the second argument as a
Long
- MultiDiff - Class in com.rpl.rama.diffs
-
Change between old and new values is represented by multiple diffs in the order in which they happened.
- MultiDiff(List<Diff>) - Constructor for class com.rpl.rama.diffs.MultiDiff
- MultiDiff.Processor - Interface in com.rpl.rama.diffs
- multiPath(Path...) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to each provided path in order, all starting from this point.
- multiPath(Path...) - Static method in interface com.rpl.rama.Path
-
Navigates to each provided path in order, all starting from this point.
- multiSet(Object) - Static method in interface com.rpl.rama.Agg
-
Aggregates input values into a java.util.Map from value to count
- MultiSetAddDiff - Class in com.rpl.rama.diffs
-
Represents a value being added to a multi-set (a map from element to count).
- MultiSetAddDiff(Object, int, int) - Constructor for class com.rpl.rama.diffs.MultiSetAddDiff
- MultiSetAddDiff.Processor - Interface in com.rpl.rama.diffs
- MultiSetRemoveDiff - Class in com.rpl.rama.diffs
-
Represents a value being removed from a multi-set (a map from element to count).
- MultiSetRemoveDiff(Object, int, int) - Constructor for class com.rpl.rama.diffs.MultiSetRemoveDiff
- MultiSetRemoveDiff.Processor - Interface in com.rpl.rama.diffs
- must(Object...) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to value for a key in a map only if key exists.
- must(Object...) - Static method in interface com.rpl.rama.Path
-
Navigates to value for a key in a map only if key exists.
N
- Navigator<T> - Interface in com.rpl.rama
-
Interface for implementing custom navigators for use in a
Path
- Navigator.Next - Interface in com.rpl.rama
- NewValueDiff - Class in com.rpl.rama.diffs
-
Old value has been replaced by a new value.
- NewValueDiff(Object) - Constructor for class com.rpl.rama.diffs.NewValueDiff
- NewValueDiff.Processor - Interface in com.rpl.rama.diffs
- nextPageMarker - Variable in class com.rpl.rama.backup.BackupProvider.KeysPage
- NONE - Enum constant in enum class com.rpl.rama.AckLevel
-
Attempts the append but doesn't get any confirmation of success or failure.
- NOT - Static variable in class com.rpl.rama.ops.Ops
-
"not" operator based on whether input is "truthy" (not null or false).
- NOT_EQUAL - Static variable in class com.rpl.rama.ops.Ops
-
Tests whether any arguments are not equal and emits boolean true or false.
- nth(Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to value for index in a list.
- nth(Object) - Static method in interface com.rpl.rama.Path
-
Navigates to value for index in a list.
- nullToList() - Method in interface com.rpl.rama.Path.Impl
-
Navigates to empty list if currently navigated to null.
- nullToList() - Static method in interface com.rpl.rama.Path
-
Navigates to empty list if currently navigated to null.
- nullToSet() - Method in interface com.rpl.rama.Path.Impl
-
Navigates to empty set if currently navigated to null.
- nullToSet() - Static method in interface com.rpl.rama.Path
-
Navigates to empty set if currently navigated to null.
- nullToVal(Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to given value if currently navigated to null.
- nullToVal(Object) - Static method in interface com.rpl.rama.Path
-
Navigates to given value if currently navigated to null.
- numWorkers(int) - Method in class com.rpl.rama.test.LaunchConfig
-
Override number of workers for module
O
- objectsToDelete(String...) - Method in interface com.rpl.rama.test.UpdateOptions.Impl
-
Sets expected PStates and depots to be deleted with the module update
- objectsToDelete(String...) - Static method in interface com.rpl.rama.test.UpdateOptions
-
Sets expected PStates and depots to be deleted with the module update
- offsetAfterTimestampMillis(int, long) - Method in interface com.rpl.rama.integration.ExternalDepot
-
Asynchronously returns the first offset of the given partition index after the given timestamp.
- OffsetAgo - Enum Class in com.rpl.rama.module
-
Enum to specify option for
MicrobatchSourceOptions.startFromOffsetAgo(long, OffsetAgo)
orStreamSourceOptions.startFromOffsetAgo(long, OffsetAgo)
- open() - Static method in interface com.rpl.rama.RamaClusterManager
-
Create a
RamaClusterManager
instance using configuration in rama.yaml file on classpath. - open(Map<String, Object>) - Static method in interface com.rpl.rama.RamaClusterManager
-
Create a
RamaClusterManager
instance using provided configuration. - openInternal() - Static method in interface com.rpl.rama.RamaClusterManager
-
Create a
RamaClusterManager
instance using configuration in rama.yaml file on classpath. - openInternal(Map<String, Object>) - Static method in interface com.rpl.rama.RamaClusterManager
-
Create a
RamaClusterManager
instance using provided configuration. - Ops - Class in com.rpl.rama.ops
- Ops() - Constructor for class com.rpl.rama.ops.Ops
- or(Object) - Static method in interface com.rpl.rama.Agg
-
Applies "or" operator to all input.
- OR - Static variable in class com.rpl.rama.ops.Ops
-
"or" operator based on values being "truthy" (not null or false).
- originPartition() - Method in interface com.rpl.rama.Block.Impl
-
Changes back to starting task for a query topology invocation.
- originPartition() - Static method in interface com.rpl.rama.Block
-
Changes back to starting task for a query topology invocation.
- originPartition() - Method in interface com.rpl.rama.Case.Impl
-
Changes back to starting task for a query topology invocation.
- originPartition() - Method in interface com.rpl.rama.SubSource.Impl
-
Changes back to starting task for a query topology invocation.
- out(String...) - Method in interface com.rpl.rama.Block.Out
-
Capture output of previous node into vars.
- out(String...) - Method in interface com.rpl.rama.Case.Out
-
Capture output of previous node into vars.
- out(String...) - Method in interface com.rpl.rama.SubSource.Out
-
Capture output of previous node into vars.
- OutputCollector - Interface in com.rpl.rama.ops
-
Interface for emitting results from custom
RamaOperation
implementations - outStream(String, String, String...) - Method in interface com.rpl.rama.Block.MultiOutImpl
-
Capture output of a non-default stream of previous node into vars.
- outStream(String, String, String...) - Method in interface com.rpl.rama.Case.MultiOutImpl
-
Capture output of a non-default stream of previous node into vars.
- outStream(String, String, String...) - Method in interface com.rpl.rama.SubSource.MultiOutImpl
-
Capture output of a non-default stream of previous node into vars.
P
- PartitionedObject - Interface in com.rpl.rama
-
Interface that has methods that are common across partitioned objects (depots, PStates).
- PartitionedObjectInfo - Class in com.rpl.rama.object
-
Information common to all partitioned objects (depots, PStates).
- PartitionedObjectInfo(String, String, long) - Constructor for class com.rpl.rama.object.PartitionedObjectInfo
- Path - Interface in com.rpl.rama
-
A Path defines how to navigate to target values in a data structure as a series of steps.
- Path.Impl - Interface in com.rpl.rama
- pathBuilder(RamaFunction0<Path>) - Method in interface com.rpl.rama.Path.Impl
-
Concatenates a path to the current path constructed with the provided function of zero arguments.
- pathBuilder(RamaFunction0<Path>) - Static method in interface com.rpl.rama.Path
-
Concatenates a path to the current path constructed with the provided function of zero arguments.
- pathBuilder(RamaFunction1<T0, Path>, Object) - Method in interface com.rpl.rama.Path.Impl
-
Concatenates a path to the current path constructed with the provided function of one argument.
- pathBuilder(RamaFunction1<T0, Path>, Object) - Static method in interface com.rpl.rama.Path
-
Concatenates a path to the current path constructed with the provided function of one argument.
- pathBuilder(RamaFunction2<T0, T1, Path>, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Concatenates a path to the current path constructed with the provided function of two arguments.
- pathBuilder(RamaFunction2<T0, T1, Path>, Object, Object) - Static method in interface com.rpl.rama.Path
-
Concatenates a path to the current path constructed with the provided function of two arguments.
- pathBuilder(RamaFunction3<T0, T1, T2, Path>, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Concatenates a path to the current path constructed with the provided function of three arguments.
- pathBuilder(RamaFunction3<T0, T1, T2, Path>, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Concatenates a path to the current path constructed with the provided function of three arguments.
- pathBuilder(RamaFunction4<T0, T1, T2, T3, Path>, Object, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Concatenates a path to the current path constructed with the provided function of four arguments.
- pathBuilder(RamaFunction4<T0, T1, T2, T3, Path>, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Concatenates a path to the current path constructed with the provided function of four arguments.
- pathBuilder(RamaFunction5<T0, T1, T2, T3, T4, Path>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Concatenates a path to the current path constructed with the provided function of five arguments.
- pathBuilder(RamaFunction5<T0, T1, T2, T3, T4, Path>, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Concatenates a path to the current path constructed with the provided function of five arguments.
- pathBuilder(RamaFunction6<T0, T1, T2, T3, T4, T5, Path>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Concatenates a path to the current path constructed with the provided function of six arguments.
- pathBuilder(RamaFunction6<T0, T1, T2, T3, T4, T5, Path>, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Concatenates a path to the current path constructed with the provided function of six arguments.
- pathBuilder(RamaFunction7<T0, T1, T2, T3, T4, T5, T6, Path>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Concatenates a path to the current path constructed with the provided function of seven arguments.
- pathBuilder(RamaFunction7<T0, T1, T2, T3, T4, T5, T6, Path>, Object, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Concatenates a path to the current path constructed with the provided function of seven arguments.
- pathBuilder(RamaFunction8<T0, T1, T2, T3, T4, T5, T6, T7, Path>, Object, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Concatenates a path to the current path constructed with the provided function of eight arguments.
- pathBuilder(RamaFunction8<T0, T1, T2, T3, T4, T5, T6, T7, Path>, Object, Object, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Concatenates a path to the current path constructed with the provided function of eight arguments.
- pathPartition(String, Path) - Method in interface com.rpl.rama.Block.Impl
-
Changes to task for given PState containing data for given
Path
- pathPartition(String, Path) - Static method in interface com.rpl.rama.Block
-
Changes to task for given PState containing data for given
Path
- pathPartition(String, Path) - Method in interface com.rpl.rama.Case.Impl
-
Changes to task for given PState containing data for given
Path
- pathPartition(String, Path) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes to task for given PState containing data for given
Path
- pauseMicrobatchTopology(String, String) - Method in interface com.rpl.rama.test.InProcessCluster
-
Pauses the specified microbatch topology so it stops processing.
- PLUS - Static variable in class com.rpl.rama.ops.Ops
-
Emits result of adding all input numbers together as an
Integer
. - PLUS_LONG - Static variable in class com.rpl.rama.ops.Ops
-
Emits result of adding all input numbers together as a
Long
. - prepareForTask(int, TaskGlobalContext) - Method in interface com.rpl.rama.integration.TaskGlobalObject
-
Specializes this object for this particular task ID.
- PRINTLN - Static variable in class com.rpl.rama.ops.Ops
-
Prints all input arguments to stdout
- process(Diff.Processor) - Method in class com.rpl.rama.diffs.Diff
- processAppendDiff(AppendDiff) - Method in interface com.rpl.rama.diffs.AppendDiff.Processor
- processDestroyedDiff(DestroyedDiff) - Method in interface com.rpl.rama.diffs.DestroyedDiff.Processor
- processKeyChangeDiff(KeyChangeDiff) - Method in interface com.rpl.rama.diffs.KeyChangeDiff.Processor
- processKeyDiff(KeyDiff) - Method in interface com.rpl.rama.diffs.KeyDiff.Processor
- processKeyRemoveDiff(KeyRemoveDiff) - Method in interface com.rpl.rama.diffs.KeyRemoveDiff.Processor
- processKeysDiff(KeysDiff) - Method in interface com.rpl.rama.diffs.KeysDiff.Processor
- processKeysRemoveDiff(KeysRemoveDiff) - Method in interface com.rpl.rama.diffs.KeysRemoveDiff.Processor
- processMultiDiff(MultiDiff) - Method in interface com.rpl.rama.diffs.MultiDiff.Processor
- processMultiSetAddDiff(MultiSetAddDiff) - Method in interface com.rpl.rama.diffs.MultiSetAddDiff.Processor
- processMultiSetRemoveDiff(MultiSetRemoveDiff) - Method in interface com.rpl.rama.diffs.MultiSetRemoveDiff.Processor
- processNewValueDiff(NewValueDiff) - Method in interface com.rpl.rama.diffs.NewValueDiff.Processor
- processResyncDiff(ResyncDiff) - Method in interface com.rpl.rama.diffs.ResyncDiff.Processor
- processSequenceChangeDiff(SequenceChangeDiff) - Method in interface com.rpl.rama.diffs.SequenceChangeDiff.Processor
- processSequenceIndexChangeDiff(SequenceIndexChangeDiff) - Method in interface com.rpl.rama.diffs.SequenceIndexChangeDiff.Processor
- processSequenceIndexChangesDiff(SequenceIndexChangesDiff) - Method in interface com.rpl.rama.diffs.SequenceIndexChangesDiff.Processor
- processSequenceIndexRemoveDiff(SequenceIndexRemoveDiff) - Method in interface com.rpl.rama.diffs.SequenceIndexRemoveDiff.Processor
- processSequenceInsertDiff(SequenceInsertDiff) - Method in interface com.rpl.rama.diffs.SequenceInsertDiff.Processor
- processSequenceInsertsDiff(SequenceInsertsDiff) - Method in interface com.rpl.rama.diffs.SequenceInsertsDiff.Processor
- processSequenceReorderDiff(SequenceReorderDiff) - Method in interface com.rpl.rama.diffs.SequenceReorderDiff.Processor
- processSetAddDiff(SetAddDiff) - Method in interface com.rpl.rama.diffs.SetAddDiff.Processor
- processSetRemoveDiff(SetRemoveDiff) - Method in interface com.rpl.rama.diffs.SetRemoveDiff.Processor
- processUngracefulTerminationDiff(UngracefulTerminationDiff) - Method in interface com.rpl.rama.diffs.UngracefulTerminationDiff.Processor
- processUnknownDiff(UnknownDiff) - Method in interface com.rpl.rama.diffs.UnknownDiff.Processor
- proxy(Path) - Method in interface com.rpl.rama.PState
-
Reactive query of PState with
Path
that must navigate to exactly one value. - proxy(Path, ProxyState.Callback<T>) - Method in interface com.rpl.rama.PState
-
Reactive query of PState with
Path
that must navigate to exactly one value. - proxy(Object, Path) - Method in interface com.rpl.rama.PState
-
Reactive query of PState using explicit partitioning key with
Path
that must navigate to exactly one value. - proxy(Object, Path, ProxyState.Callback<T>) - Method in interface com.rpl.rama.PState
-
Reactive query of PState using explicit partitioning key with
Path
that must navigate to exactly one value. - proxyAsync(Path) - Method in interface com.rpl.rama.PState
-
Reactive query of PState with
Path
that must navigate to exactly one value. - proxyAsync(Path, ProxyState.Callback<T>) - Method in interface com.rpl.rama.PState
-
Reactive query of PState with
Path
that must navigate to exactly one value. - proxyAsync(Object, Path) - Method in interface com.rpl.rama.PState
-
Reactive query of PState using explicit partitioning key with
Path
that must navigate to exactly one value. - proxyAsync(Object, Path, ProxyState.Callback<T>) - Method in interface com.rpl.rama.PState
-
Reactive query of PState using explicit partitioning key with
Path
that must navigate to exactly one value. - ProxyState<T> - Interface in com.rpl.rama
-
Reactive result of one of
PState
proxy
methods. - ProxyState.Callback<T> - Interface in com.rpl.rama
-
Interface for specifying callbacks for fine-grained diffs as data changes
- ProxyState.Status - Enum Class in com.rpl.rama
- pstate(String, PState.Schema) - Method in interface com.rpl.rama.module.ETLTopologyBase
-
Declares a PState owned by this topology.
- pstate(String, Class) - Method in interface com.rpl.rama.module.ETLTopologyBase
-
Declares a PState owned by this topology.
- PState - Interface in com.rpl.rama
-
Interface for thread-safe PState clients.
- PState.Declaration - Interface in com.rpl.rama
-
Builder-style interface for specifying options when declaring a PState in a module
- PState.MigratedSchema - Interface in com.rpl.rama
-
Builder-style interface for declaring options on a migrated schema declared with
PState.migrated(java.lang.Object, java.lang.String, com.rpl.rama.ops.RamaFunction1<?, ?>)
- PState.Schema - Interface in com.rpl.rama
-
Builder-style interface for declaring options on PState schemas
- putCollected(Object) - Method in interface com.rpl.rama.Path.Impl
-
Adds given value to collected values.
- putCollected(Object) - Static method in interface com.rpl.rama.Path
-
Adds given value to collected values.
- putObject(String, InputStream, Long) - Method in interface com.rpl.rama.backup.BackupProvider
-
Put the contents of path to the backup provider at the given key.
Q
- query(String, String...) - Method in interface com.rpl.rama.RamaModule.Topologies
-
Defines a query topology.
- QueryTopologyClient<T> - Interface in com.rpl.rama
-
Client for invoking a query topology.
R
- RamaAccumulatorAgg<V> - Interface in com.rpl.rama.ops
-
Base interface for custom accumulator implementations.
- RamaAccumulatorAgg0<V> - Interface in com.rpl.rama.ops
-
Interface for custom accumulator implementations of zero arguments.
- RamaAccumulatorAgg1<V,
T0> - Interface in com.rpl.rama.ops -
Interface for custom accumulator implementations of one argument.
- RamaAccumulatorAgg2<V,
T0, - Interface in com.rpl.rama.opsT1> -
Interface for custom accumulator implementations of two arguments.
- RamaAccumulatorAgg3<V,
T0, - Interface in com.rpl.rama.opsT1, T2> -
Interface for custom accumulator implementations of three arguments.
- RamaAccumulatorAgg4<V,
T0, - Interface in com.rpl.rama.opsT1, T2, T3> -
Interface for custom accumulator implementations of four arguments.
- RamaAccumulatorAgg5<V,
T0, - Interface in com.rpl.rama.opsT1, T2, T3, T4> -
Interface for custom accumulator implementations of five arguments.
- RamaAccumulatorAgg6<V,
T0, - Interface in com.rpl.rama.opsT1, T2, T3, T4, T5> -
Interface for custom accumulator implementations of six arguments.
- RamaAccumulatorAgg7<V,
T0, - Interface in com.rpl.rama.opsT1, T2, T3, T4, T5, T6> -
Interface for custom accumulator implementations of seven arguments.
- RamaAccumulatorAgg8<V,
T0, - Interface in com.rpl.rama.opsT1, T2, T3, T4, T5, T6, T7> -
Interface for custom accumulator implementations of eight arguments.
- RamaClusterManager - Interface in com.rpl.rama
-
API for connecting to a Rama cluster and getting clients for depots, PStates, and query topologies.
- RamaCombinerAgg<T> - Interface in com.rpl.rama.ops
-
Base interface for custom combiner implementations.
- RamaCompileException - Exception Class in com.rpl.rama
- RamaCompileException(String) - Constructor for exception class com.rpl.rama.RamaCompileException
- RamaCompileException(String, Exception) - Constructor for exception class com.rpl.rama.RamaCompileException
- RamaCustomSerialization<T> - Interface in com.rpl.rama
-
Interface for implementing serialization for custom types.
- RamaFunction - Interface in com.rpl.rama.ops
-
Base interface for custom function implementations.
- RamaFunction0<R> - Interface in com.rpl.rama.ops
-
Interface for custom function implementations of zero arguments
- RamaFunction1<T0,
R> - Interface in com.rpl.rama.ops -
Interface for custom function implementations of one argument
- RamaFunction2<T0,
T1, - Interface in com.rpl.rama.opsR> -
Interface for custom function implementations of two arguments
- RamaFunction3<T0,
T1, - Interface in com.rpl.rama.opsT2, R> -
Interface for custom function implementations of three arguments
- RamaFunction4<T0,
T1, - Interface in com.rpl.rama.opsT2, T3, R> -
Interface for custom function implementations of four arguments
- RamaFunction5<T0,
T1, - Interface in com.rpl.rama.opsT2, T3, T4, R> -
Interface for custom function implementations of five arguments
- RamaFunction6<T0,
T1, - Interface in com.rpl.rama.opsT2, T3, T4, T5, R> -
Interface for custom function implementations of six arguments
- RamaFunction7<T0,
T1, - Interface in com.rpl.rama.opsT2, T3, T4, T5, T6, R> -
Interface for custom function implementations of seven arguments
- RamaFunction8<T0,
T1, - Interface in com.rpl.rama.opsT2, T3, T4, T5, T6, T7, R> -
Interface for custom function implementations of eight arguments
- RamaModule - Interface in com.rpl.rama
-
Defines a Rama module.
A module specifies an arbitrary collection of depots, ETLs, PStates, and query topologies to deploy onto a Rama cluster. - RamaModule.Setup - Interface in com.rpl.rama
-
Used to define depots, global objects, and module dependencies in a module definition.
- RamaModule.Topologies - Interface in com.rpl.rama
-
Used to define ETL and query topologies in a module definition.
- RamaOperation - Interface in com.rpl.rama.ops
-
Base interface for custom operation implementations.
- RamaOperation0 - Interface in com.rpl.rama.ops
-
Interface for custom operation implementation of zero arguments.
- RamaOperation1<T0> - Interface in com.rpl.rama.ops
-
Interface for custom operation implementation of one argument.
- RamaOperation2<T0,
T1> - Interface in com.rpl.rama.ops -
Interface for custom operation implementation of two arguments.
- RamaOperation3<T0,
T1, - Interface in com.rpl.rama.opsT2> -
Interface for custom operation implementation of three arguments.
- RamaOperation4<T0,
T1, - Interface in com.rpl.rama.opsT2, T3> -
Interface for custom operation implementation of four arguments.
- RamaOperation5<T0,
T1, - Interface in com.rpl.rama.opsT2, T3, T4> -
Interface for custom operation implementation of five arguments.
- RamaOperation6<T0,
T1, - Interface in com.rpl.rama.opsT2, T3, T4, T5> -
Interface for custom operation implementation of six arguments.
- RamaOperation7<T0,
T1, - Interface in com.rpl.rama.opsT2, T3, T4, T5, T6> -
Interface for custom operation implementation of seven arguments.
- RamaOperation8<T0,
T1, - Interface in com.rpl.rama.opsT2, T3, T4, T5, T6, T7> -
Interface for custom operation implementation of eight arguments.
- RamaSerializable - Interface in com.rpl.rama
-
Objects implementing this interface will be serialized by Rama across disk or network boundaries using Java serialization.
- random() - Static method in interface com.rpl.rama.Depot
-
Depot partitioning where each append goes to a random partition
- RANGE - Static variable in class com.rpl.rama.ops.Ops
-
Arguments are a starting integer (inclusive) and an end integer (exclusive) and emits each integer between than range individually Example:
Block.each(Ops.RANGE, 10, 20).out("*i")
- read(long, long, long) - Method in interface com.rpl.rama.Depot
-
Reads records from the log for the specified partition index of the depot, between the given start and end offsets.
- readAsync(long, long, long) - Method in interface com.rpl.rama.Depot
-
Reads records from the log for the specified partition index of the depot, between the given start and end offsets.
- RECORDS - Enum constant in enum class com.rpl.rama.module.OffsetAgo
-
Start from this number of records in the past
- removeFixedKeys(Object...) - Method in interface com.rpl.rama.PState.MigratedSchema
-
Migration option to specify keys being removed from a
fixedKeysSchema
. - resumeMicrobatchTopology(String, String) - Method in interface com.rpl.rama.test.InProcessCluster
-
Resumes a paused microbatch topology so it starts processing again.
- ResyncDiff - Class in com.rpl.rama.diffs
-
Represents value being re-queried from scratch.
- ResyncDiff() - Constructor for class com.rpl.rama.diffs.ResyncDiff
- ResyncDiff.Processor - Interface in com.rpl.rama.diffs
- retryAllAfter() - Method in interface com.rpl.rama.module.StreamSourceOptions.Impl
-
Retry failed records and all records after in the same depot partition
- retryAllAfter() - Static method in interface com.rpl.rama.module.StreamSourceOptions
-
Retry failed records and all records after in the same depot partition
- retryNone() - Method in interface com.rpl.rama.module.StreamSourceOptions.Impl
-
Never retry a failed depot record
- retryNone() - Static method in interface com.rpl.rama.module.StreamSourceOptions
-
Never retry a failed depot record
- reverse() - Method in interface com.rpl.rama.ops.LimitAgg
-
Used in conjunction with
LimitAgg.sort(java.lang.String...)
to reverse the input - RocksDBOptionsBuilder - Interface in com.rpl.rama
-
Rama uses RocksDB in the underlying implementation for PStates that have a map in the top-level schema.
S
- SECONDS - Enum constant in enum class com.rpl.rama.module.OffsetAgo
-
Start from first record added after this many seconds in the past
- select(Path) - Method in interface com.rpl.rama.PState
-
Queries PState with
Path
. - select(Path) - Method in interface com.rpl.rama.test.TestPState
-
Queries PState with
Path
. - select(Object, Path) - Method in interface com.rpl.rama.Block.Impl
-
Changes to task for given PState containing data for given
Path
and then performs alocalSelect
. - select(Object, Path) - Static method in interface com.rpl.rama.Block
-
Changes to task for given PState containing data for given
Path
and then performs alocalSelect
. - select(Object, Path) - Method in interface com.rpl.rama.Case.Impl
-
Changes to task for given PState containing data for given
Path
and then performs alocalSelect
. - select(Object, Path) - Method in interface com.rpl.rama.PState
-
Queries PState with
Path
using explicit partitioning key. - select(Object, Path) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes to task for given PState containing data for given
Path
and then performs alocalSelect
. - select(Object, Path, SelectOptions) - Method in interface com.rpl.rama.Block.Impl
-
Changes to task for given PState containing data for given
Path
and then performs alocalSelect
. - select(Object, Path, SelectOptions) - Static method in interface com.rpl.rama.Block
-
Changes to task for given PState containing data for given
Path
and then performs alocalSelect
. - select(Object, Path, SelectOptions) - Method in interface com.rpl.rama.Case.Impl
-
Changes to task for given PState containing data for given
Path
and then performs alocalSelect
. - select(Object, Path, SelectOptions) - Method in interface com.rpl.rama.SubSource.Impl
-
Changes to task for given PState containing data for given
Path
and then performs alocalSelect
. - select(T, Navigator.Next) - Method in interface com.rpl.rama.Navigator
-
Implements codepath for select calls.
- selectAsync(Path) - Method in interface com.rpl.rama.PState
-
Queries PState with
Path
. - selectAsync(Object, Path) - Method in interface com.rpl.rama.PState
-
Queries PState with
Path
using explicit partitioning key. - selectOne(Path) - Method in interface com.rpl.rama.PState
-
Queries PState with
Path
that must navigate to exactly one value. - selectOne(Path) - Method in interface com.rpl.rama.test.TestPState
-
Queries PState with
Path
that must navigate to exactly one value. - selectOne(Object, Path) - Method in interface com.rpl.rama.PState
-
Queries PState using explicit partitioning key with
Path
that must navigate to exactly one value. - selectOneAsync(Path) - Method in interface com.rpl.rama.PState
-
Queries PState with
Path
that must navigate to exactly one value. - selectOneAsync(Object, Path) - Method in interface com.rpl.rama.PState
-
Queries PState using explicit partitioning key with
Path
that must navigate to exactly one value. - SelectOptions - Interface in com.rpl.rama
-
Interface for declaring options for select calls in topologies.
- SelectOptions.CaptureSelectOptions - Class in com.rpl.rama
- SelectOptions.Impl - Interface in com.rpl.rama
- SequenceChangeDiff - Class in com.rpl.rama.diffs
-
Represents unknown change to a sequence starting from a particular index.
- SequenceChangeDiff(int, int, int) - Constructor for class com.rpl.rama.diffs.SequenceChangeDiff
- SequenceChangeDiff.Processor - Interface in com.rpl.rama.diffs
- SequenceIndexChangeDiff - Class in com.rpl.rama.diffs
-
Represents a value for an index of a sequence changing.
- SequenceIndexChangeDiff(int, Diff) - Constructor for class com.rpl.rama.diffs.SequenceIndexChangeDiff
- SequenceIndexChangeDiff.Processor - Interface in com.rpl.rama.diffs
- SequenceIndexChangesDiff - Class in com.rpl.rama.diffs
-
Represents changes for values for multiple indexes in a sequence.
- SequenceIndexChangesDiff(Map<Integer, Diff>) - Constructor for class com.rpl.rama.diffs.SequenceIndexChangesDiff
- SequenceIndexChangesDiff.Processor - Interface in com.rpl.rama.diffs
- SequenceIndexRemoveDiff - Class in com.rpl.rama.diffs
-
Represents one or more values being removed starting at some index in a sequence.
- SequenceIndexRemoveDiff(int, int, int) - Constructor for class com.rpl.rama.diffs.SequenceIndexRemoveDiff
- SequenceIndexRemoveDiff.Processor - Interface in com.rpl.rama.diffs
- SequenceInsertDiff - Class in com.rpl.rama.diffs
-
Represents a value being inserted at some index in a sequence.
- SequenceInsertDiff(int, Object, int) - Constructor for class com.rpl.rama.diffs.SequenceInsertDiff
- SequenceInsertDiff.Processor - Interface in com.rpl.rama.diffs
- SequenceInsertsDiff - Class in com.rpl.rama.diffs
-
Represents multiple values being inserted at some index in a sequence.
- SequenceInsertsDiff(int, List<Object>, int) - Constructor for class com.rpl.rama.diffs.SequenceInsertsDiff
- SequenceInsertsDiff.Processor - Interface in com.rpl.rama.diffs
- SequenceReorderDiff - Class in com.rpl.rama.diffs
-
Represents a value in a sequence being moved from one index to another, shifting other values to new indexes in the process.
- SequenceReorderDiff(int, int, int) - Constructor for class com.rpl.rama.diffs.SequenceReorderDiff
- SequenceReorderDiff.Processor - Interface in com.rpl.rama.diffs
- serialize(T, DataOutput) - Method in interface com.rpl.rama.RamaCustomSerialization
-
Serializes an object
- set(Object) - Static method in interface com.rpl.rama.Agg
-
Aggregates all input to a java.util.Set data structure.
- SetAddDiff - Class in com.rpl.rama.diffs
-
Represents a value being added to a set.
- SetAddDiff(Object) - Constructor for class com.rpl.rama.diffs.SetAddDiff
- SetAddDiff.Processor - Interface in com.rpl.rama.diffs
- setElem(Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to element of set if it exists.
- setElem(Object) - Static method in interface com.rpl.rama.Path
-
Navigates to element of set if it exists.
- setLaunchDepotDynamicOption(String, String, Object) - Method in interface com.rpl.rama.RamaModule.Setup
-
Sets the value of a depot dynamic option to be used on module launch, unless an explicit override is provided at deploy time.
- setLaunchModuleDynamicOption(String, Object) - Method in interface com.rpl.rama.RamaModule.Setup
-
Sets the value of a module dynamic option to be used on module launch, unless an explicit override is provided at deploy time.
- setLaunchPStateDynamicOption(String, String, Object) - Method in interface com.rpl.rama.RamaModule.Setup
-
Sets the value of a PState dynamic option to be used on module launch, unless an explicit override is provided at deploy time.
- setLaunchTopologyDynamicOption(String, String, Object) - Method in interface com.rpl.rama.RamaModule.Setup
-
Sets the value of a topology dynamic option to be used on module launch, unless an explicit override is provided at deploy time.
- setOptions(String, Options) - Method in interface com.rpl.rama.RocksDBOptionsBuilder
- setRemove(Object) - Static method in interface com.rpl.rama.Agg
-
Aggregates to "void" value for the given java.util.Set element.
- SetRemoveDiff - Class in com.rpl.rama.diffs
-
Represents a value being removed from a set.
- SetRemoveDiff(Object) - Constructor for class com.rpl.rama.diffs.SetRemoveDiff
- SetRemoveDiff.Processor - Interface in com.rpl.rama.diffs
- setSchema(Class) - Static method in interface com.rpl.rama.PState
-
Declare a set schema
- shufflePartition() - Method in interface com.rpl.rama.Block.Impl
-
Changes to a random task chosen uniformly.
- shufflePartition() - Static method in interface com.rpl.rama.Block
-
Changes to a random task chosen uniformly.
- shufflePartition() - Method in interface com.rpl.rama.Case.Impl
-
Changes to a random task chosen uniformly.
- shufflePartition() - Method in interface com.rpl.rama.SubSource.Impl
-
Changes to a random task chosen uniformly.
- SIZE - Static variable in class com.rpl.rama.ops.Ops
-
Emits size of input collection as an
Integer
- sort(String...) - Method in interface com.rpl.rama.ops.LimitAgg
-
Sort input for aggregation on values of given vars
- sortedMapRange(Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a sorted map to a sorted map of all elements in that map between a range of keys.
- sortedMapRange(Object, Object) - Static method in interface com.rpl.rama.Path
-
Navigates on a sorted map to a sorted map of all elements in that map between a range of keys.
- sortedMapRange(Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a sorted map to a sorted map of all elements in that map between a range of keys, with options to change inclusive/exclusive status of start and end keys.
- sortedMapRange(Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Navigates on a sorted map to a sorted map of all elements in that map between a range of keys, with options to change inclusive/exclusive status of start and end keys.
- sortedMapRangeFrom(Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a sorted map to a sorted map of all elements in that map after a key.
- sortedMapRangeFrom(Object) - Static method in interface com.rpl.rama.Path
-
Navigates on a sorted map to a sorted map of all elements in that map after a key.
- sortedMapRangeFrom(Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a sorted map to a sorted map starting from a specified key, with options to read a fixed number of elements or configure whether start key is inclusive or exclusive.
- sortedMapRangeFrom(Object, Object) - Static method in interface com.rpl.rama.Path
-
Navigates on a sorted map to a sorted map starting from a specified key, with options to read a fixed number of elements or configure whether start key is inclusive or exclusive.
- sortedMapRangeFromStart(Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a sorted map to a sorted map of all elements in that map from the start up to the provided max amount.
- sortedMapRangeFromStart(Object) - Static method in interface com.rpl.rama.Path
-
Navigates on a sorted map to a sorted map of all elements in that map from the start up to the provided max amount.
- sortedMapRangeTo(Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a sorted map to a sorted map of all values in that map up to a key.
- sortedMapRangeTo(Object) - Static method in interface com.rpl.rama.Path
-
Navigates on a sorted map to a sorted map of all values in that map up to a key.
- sortedMapRangeTo(Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a sorted map to a sorted map up to a specified key, with options to read a fixed number of elements or configure whether end key is inclusive or exclusive.
- sortedMapRangeTo(Object, Object) - Static method in interface com.rpl.rama.Path
-
Navigates on a sorted map to a sorted map up to a specified key, with options to read a fixed number of elements or configure whether end key is inclusive or exclusive.
- sortedMapRangeToEnd(Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a sorted map to a sorted map of all elements in that map from the end up to the provided max amount.
- sortedMapRangeToEnd(Object) - Static method in interface com.rpl.rama.Path
-
Navigates on a sorted map to a sorted map of all elements in that map from the end up to the provided max amount.
- SortedRangeFromOptions - Interface in com.rpl.rama
-
Interface for declaring options for
Path.sortedMapRangeFrom(java.lang.Object)
orPath.sortedSetRangeFrom(java.lang.Object)
. - SortedRangeFromOptions.CapturedSortedRangeFromOptions - Class in com.rpl.rama
- SortedRangeFromOptions.Impl - Interface in com.rpl.rama
- SortedRangeOptions - Interface in com.rpl.rama
-
Interface for declaring options for
Path.sortedMapRange(java.lang.Object, java.lang.Object)
orPath.sortedSetRange(java.lang.Object, java.lang.Object)
. - SortedRangeOptions.CapturedSortedRangeOptions - Class in com.rpl.rama
- SortedRangeOptions.Impl - Interface in com.rpl.rama
- SortedRangeToOptions - Interface in com.rpl.rama
-
Interface for declaring options for
Path.sortedMapRangeTo(java.lang.Object)
orPath.sortedSetRangeTo(java.lang.Object)
. - SortedRangeToOptions.CapturedSortedRangeToOptions - Class in com.rpl.rama
- SortedRangeToOptions.Impl - Interface in com.rpl.rama
- sortedSetRange(Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a sorted set to a sorted set of all values in that set between a range.
- sortedSetRange(Object, Object) - Static method in interface com.rpl.rama.Path
-
Navigates on a sorted set to a sorted set of all values in that set between a range.
- sortedSetRange(Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a sorted set to a sorted set of all values in that set between a range, with options to change inclusive/exclusive status of start and end elements.
- sortedSetRange(Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Navigates on a sorted set to a sorted set of all values in that set between a range, with options to change inclusive/exclusive status of start and end elements.
- sortedSetRangeFrom(Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a sorted set to a sorted set of all values in that set after an element.
- sortedSetRangeFrom(Object) - Static method in interface com.rpl.rama.Path
-
Navigates on a sorted set to a sorted set of all values in that set after an element.
- sortedSetRangeFrom(Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a sorted set to a sorted set starting from a specified element, with options to read a fixed number of elements or configure whether start element is inclusive or exclusive.
- sortedSetRangeFrom(Object, Object) - Static method in interface com.rpl.rama.Path
-
Navigates on a sorted set to a sorted set starting from a specified element, with options to read a fixed number of elements or configure whether start element is inclusive or exclusive.
- sortedSetRangeFromStart(Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a sorted set to a sorted set of all values in that set after the start up to the provided max amount.
- sortedSetRangeFromStart(Object) - Static method in interface com.rpl.rama.Path
-
Navigates on a sorted set to a sorted set of all values in that set after the start up to the provided max amount.
- sortedSetRangeTo(Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a sorted set to a sorted set of all values in that set up to an element.
- sortedSetRangeTo(Object) - Static method in interface com.rpl.rama.Path
-
Navigates on a sorted set to a sorted set of all values in that set up to an element.
- sortedSetRangeTo(Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a sorted set to a sorted set up to a specified element, with options to read a fixed number of elements or configure whether end element is inclusive or exclusive.
- sortedSetRangeTo(Object, Object) - Static method in interface com.rpl.rama.Path
-
Navigates on a sorted set to a sorted set up to a specified element, with options to read a fixed number of elements or configure whether end element is inclusive or exclusive.
- sortedSetRangeToEnd(Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates on a sorted set to a sorted set of all values in that set from the end, up to the provided max amount.
- sortedSetRangeToEnd(Object) - Static method in interface com.rpl.rama.Path
-
Navigates on a sorted set to a sorted set of all values in that set from the end, up to the provided max amount.
- sortValFunction(RamaFunction1<T, R>) - Method in interface com.rpl.rama.ops.TopMonotonicAgg
-
Function to extract from data the value to sort with for aggregation
- source(String) - Method in interface com.rpl.rama.module.ETLTopologyBase
-
Add depot source to topology
- source(String, T) - Method in interface com.rpl.rama.module.ETLTopologyBase
-
Add depot source with specified options to topology
- sourceId(String) - Method in interface com.rpl.rama.module.MicrobatchSourceOptions.Impl
-
The source ID for this subscription.
- sourceId(String) - Static method in interface com.rpl.rama.module.MicrobatchSourceOptions
-
The source ID for this subscription.
- sourceId(String) - Method in interface com.rpl.rama.module.StreamSourceOptions.Impl
-
The source ID for this subscription.
- sourceId(String) - Static method in interface com.rpl.rama.module.StreamSourceOptions
-
The source ID for this subscription.
- startFromBeginning() - Method in interface com.rpl.rama.module.MicrobatchSourceOptions.Impl
-
Start processing from beginning of depot partition.
- startFromBeginning() - Static method in interface com.rpl.rama.module.MicrobatchSourceOptions
-
Start processing from beginning of depot partition.
- startFromBeginning() - Method in interface com.rpl.rama.module.StreamSourceOptions.Impl
-
Start processing from beginning of depot partition.
- startFromBeginning() - Static method in interface com.rpl.rama.module.StreamSourceOptions
-
Start processing from beginning of depot partition.
- startFromOffsetAfterTimestamp(long) - Method in interface com.rpl.rama.module.MicrobatchSourceOptions.Impl
-
Start processing each depot partition from a point in the past.
- startFromOffsetAfterTimestamp(long) - Static method in interface com.rpl.rama.module.MicrobatchSourceOptions
-
Start processing each depot partition from a point in the past.
- startFromOffsetAfterTimestamp(long) - Method in interface com.rpl.rama.module.StreamSourceOptions.Impl
-
Start processing each depot partition from a point in the past.
- startFromOffsetAfterTimestamp(long) - Static method in interface com.rpl.rama.module.StreamSourceOptions
-
Start processing each depot partition from a point in the past.
- startFromOffsetAgo(long, OffsetAgo) - Method in interface com.rpl.rama.module.MicrobatchSourceOptions.Impl
-
Start processing each depot partition from a point in the past.
- startFromOffsetAgo(long, OffsetAgo) - Static method in interface com.rpl.rama.module.MicrobatchSourceOptions
-
Start processing each depot partition from a point in the past.
- startFromOffsetAgo(long, OffsetAgo) - Method in interface com.rpl.rama.module.StreamSourceOptions.Impl
-
Start processing each depot partition from a point in the past.
- startFromOffsetAgo(long, OffsetAgo) - Static method in interface com.rpl.rama.module.StreamSourceOptions
-
Start processing each depot partition from a point in the past.
- startOffset(int) - Method in interface com.rpl.rama.integration.ExternalDepot
-
Asynchronously returns the start offset of the given partition index (inclusive).
- staticData(List<Object>) - Static method in class com.rpl.rama.SubBatch
-
Create a subbatch that emits the provided data.
- status() - Method in interface com.rpl.rama.ProxyState
-
Returns current status of this ProxyState.
- stay() - Method in interface com.rpl.rama.Path.Impl
-
No-op that stays navigated at current point.
- stay() - Static method in interface com.rpl.rama.Path
-
No-op that stays navigated at current point.
- stop() - Method in interface com.rpl.rama.Path.Impl
-
Stops current branch of navigation.
- stop() - Static method in interface com.rpl.rama.Path
-
Stops current branch of navigation.
- stream(String) - Method in interface com.rpl.rama.RamaModule.Topologies
-
Defines a stream topology.
- StreamSourceOptions - Interface in com.rpl.rama.module
-
Depot source options for stream topologies using builder pattern Stream topologies documentation
- StreamSourceOptions.Impl - Interface in com.rpl.rama.module
- StreamTopology - Interface in com.rpl.rama.module
- subBatch(SubBatch) - Method in interface com.rpl.rama.Block.Impl
-
Use specified SubBatch as a batch source in a
batch block
. - subBatch(SubBatch) - Static method in interface com.rpl.rama.Block
-
Use specified SubBatch as a batch source in a
batch block
. - subBatch(SubBatch) - Method in interface com.rpl.rama.Case.Impl
-
Use specified SubBatch as a batch source in a
batch block
. - subBatch(SubBatch) - Method in interface com.rpl.rama.SubSource.Impl
-
Use specified SubBatch as a batch source in a
batch block
. - SubBatch - Class in com.rpl.rama
-
Represents a subbatch for use with
subBatch
in a batch block - SubBatch(Block, String...) - Constructor for class com.rpl.rama.SubBatch
-
Create a subbatch with the given code and specified output vars
- subindexed() - Method in interface com.rpl.rama.PState.Schema
-
Declare this data structure as subindexed.
- subindexed(SubindexOptions) - Method in interface com.rpl.rama.PState.Schema
-
Declare this data structure as subindexed with the given options.
- SubindexOptions - Interface in com.rpl.rama
-
Interface for declaring options on a subindexed PState schema
- SubindexOptions.CapturedSubindexOptions - Class in com.rpl.rama
- SubindexOptions.Impl - Interface in com.rpl.rama
- sublist(Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to sublist bounded by two indexes.
- sublist(Object, Object) - Static method in interface com.rpl.rama.Path
-
Navigates to sublist bounded by two indexes.
- sublistDynamic(RamaFunction1<T0, R0>, RamaFunction2<T1, T2, R1>) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to sublist bounded by indexes chosen by functions.
- sublistDynamic(RamaFunction1<T0, R0>, RamaFunction2<T1, T2, R1>) - Static method in interface com.rpl.rama.Path
-
Navigates to sublist bounded by indexes chosen by functions.
- subMap(Object...) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to a map containing subset of keys/values of starting map.
- subMap(Object...) - Static method in interface com.rpl.rama.Path
-
Navigates to a map containing subset of keys/values of starting map.
- subselect(Path) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to list of values navigated by provided path.
- subselect(Path) - Static method in interface com.rpl.rama.Path
-
Navigates to list of values navigated by provided path.
- subset(Object...) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to subset of starting set with given elements.
- subset(Object...) - Static method in interface com.rpl.rama.Path
-
Navigates to subset of starting set with given elements.
- subSource(Object, SubSource...) - Method in interface com.rpl.rama.Block.Impl
-
Conditionally dispatch code based on type of input object
- subSource(Object, SubSource...) - Static method in interface com.rpl.rama.Block
-
Conditionally dispatch code based on type of input object
- subSource(Object, SubSource...) - Method in interface com.rpl.rama.Case.Impl
-
Conditionally dispatch code based on type of input object
- subSource(Object, SubSource...) - Method in interface com.rpl.rama.SubSource.Impl
-
Conditionally dispatch code based on type of input object
- SubSource - Interface in com.rpl.rama
-
Used to create cases for
Block.subSource(java.lang.Object, com.rpl.rama.SubSource...)
- SubSource.Impl - Interface in com.rpl.rama
- SubSource.MultiOutImpl - Interface in com.rpl.rama
- SubSource.Out - Interface in com.rpl.rama
- SubSource.OutImpl - Interface in com.rpl.rama
- sum(Object) - Static method in interface com.rpl.rama.Agg
-
Sums input values into a java.lang.Long
- SUM - Static variable in class com.rpl.rama.ops.Ops
-
Emits sum of all numbers in input list as an
Integer
. - SUM_LONG - Static variable in class com.rpl.rama.ops.Ops
-
Emits sum of all numbers in input list as a
Long
.
T
- targetType() - Method in interface com.rpl.rama.RamaCustomSerialization
-
Base type targetted by this serializer.
- TaskGlobalContext - Interface in com.rpl.rama.integration
-
Provides contextual information for
TaskGlobalObject.prepareForTask(int, TaskGlobalContext)
. - TaskGlobalObject - Interface in com.rpl.rama.integration
-
Objects implementing this interface that are provided to
RamaModule.Setup.declareObject(String, Object)
can specialize their implementation per task. - TaskGlobalObjectWithTick - Interface in com.rpl.rama.integration
-
Defines a
task global object
that will haveTaskGlobalObjectWithTick.tick()
called at a regular frequency. - TaskThreadManagedResource<T> - Class in com.rpl.rama.integration
-
Used for sharing resources across tasks in a task thread
- TaskThreadManagedResource(String, TaskGlobalContext, Callable<T>) - Constructor for class com.rpl.rama.integration.TaskThreadManagedResource
- term(RamaFunction1<T0, R0>) - Method in interface com.rpl.rama.Path.Impl
-
Terminal point of a transform path that updates navigated value with the provided function of one argument.
- term(RamaFunction1<T0, R0>) - Static method in interface com.rpl.rama.Path
-
Terminal point of a transform path that updates navigated value with the provided function of one argument.
- term(RamaFunction2<T0, T1, R0>, Object) - Method in interface com.rpl.rama.Path.Impl
-
Terminal point of a transform path that updates navigated value with the provided function of two arguments.
- term(RamaFunction2<T0, T1, R0>, Object) - Static method in interface com.rpl.rama.Path
-
Terminal point of a transform path that updates navigated value with the provided function of two arguments.
- term(RamaFunction3<T0, T1, T2, R0>, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Terminal point of a transform path that updates navigated value with the provided function of three arguments.
- term(RamaFunction3<T0, T1, T2, R0>, Object, Object) - Static method in interface com.rpl.rama.Path
-
Terminal point of a transform path that updates navigated value with the provided function of three arguments.
- term(RamaFunction4<T0, T1, T2, T3, R0>, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Terminal point of a transform path that updates navigated value with the provided function of four arguments.
- term(RamaFunction4<T0, T1, T2, T3, R0>, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Terminal point of a transform path that updates navigated value with the provided function of four arguments.
- term(RamaFunction5<T0, T1, T2, T3, T4, R0>, Object, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Terminal point of a transform path that updates navigated value with the provided function of five arguments.
- term(RamaFunction5<T0, T1, T2, T3, T4, R0>, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Terminal point of a transform path that updates navigated value with the provided function of five arguments.
- term(RamaFunction6<T0, T1, T2, T3, T4, T5, R0>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Terminal point of a transform path that updates navigated value with the provided function of six arguments.
- term(RamaFunction6<T0, T1, T2, T3, T4, T5, R0>, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Terminal point of a transform path that updates navigated value with the provided function of six arguments.
- term(RamaFunction7<T0, T1, T2, T3, T4, T5, T6, R0>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Terminal point of a transform path that updates navigated value with the provided function of seven arguments.
- term(RamaFunction7<T0, T1, T2, T3, T4, T5, T6, R0>, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Terminal point of a transform path that updates navigated value with the provided function of seven arguments.
- term(RamaFunction8<T0, T1, T2, T3, T4, T5, T6, T7, R0>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Terminal point of a transform path that updates navigated value with the provided function of eight arguments.
- term(RamaFunction8<T0, T1, T2, T3, T4, T5, T6, T7, R0>, Object, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Terminal point of a transform path that updates navigated value with the provided function of eight arguments.
- TERMINATED - Enum constant in enum class com.rpl.rama.ProxyState.Status
- TERMINATED_UNGRACEFULLY - Enum constant in enum class com.rpl.rama.ProxyState.Status
- termVal(Object) - Method in interface com.rpl.rama.Path.Impl
-
Terminal point of a transform path that overrides navigated value to provided value
- termVal(Object) - Static method in interface com.rpl.rama.Path
-
Terminal point of a transform path that overrides navigated value to provided value
- termVoid() - Method in interface com.rpl.rama.Path.Impl
-
Terminal point of a transform path that sets navigated value to void, causing it to be removed.
- termVoid() - Static method in interface com.rpl.rama.Path
-
Terminal point of a transform path that sets navigated value to void, causing it to be removed.
- testProvider(BackupProvider) - Static method in class com.rpl.rama.backup.BackupProviderTester
- TestPState - Interface in com.rpl.rama.test
-
Helper utility compatible with
Block.localSelect(java.lang.String, com.rpl.rama.Path)
andBlock.localTransform(java.lang.String, com.rpl.rama.Path)
. - tick() - Method in interface com.rpl.rama.integration.TaskGlobalObjectWithTick
-
Implement this method to define desired behavior on each tick.
- TIMES - Static variable in class com.rpl.rama.ops.Ops
-
Emits result of multiplying all input numbers together as an
Integer
. - TIMES_LONG - Static variable in class com.rpl.rama.ops.Ops
-
Emits result of multiplying all input numbers together as a
Long
. - TO_STRING - Static variable in class com.rpl.rama.ops.Ops
-
Emits result of converting all input arguments to strings and concatenating them together
- TOMBSTONE - Static variable in interface com.rpl.rama.Depot
-
Object used as return value in a depot migration to delete record.
- topMonotonic(int, String) - Static method in interface com.rpl.rama.Agg
-
Aggregates input into a list of top elements.
- TopMonotonicAgg - Interface in com.rpl.rama.ops
-
Builder-style object for customizing options to a call to
Agg.topMonotonic(int, java.lang.String)
- toString() - Method in class com.rpl.rama.diffs.AppendDiff
- toString() - Method in class com.rpl.rama.diffs.DestroyedDiff
- toString() - Method in class com.rpl.rama.diffs.KeyChangeDiff
- toString() - Method in class com.rpl.rama.diffs.KeyDiff
- toString() - Method in class com.rpl.rama.diffs.KeyRemoveDiff
- toString() - Method in class com.rpl.rama.diffs.KeysDiff
- toString() - Method in class com.rpl.rama.diffs.KeysRemoveDiff
- toString() - Method in class com.rpl.rama.diffs.MultiDiff
- toString() - Method in class com.rpl.rama.diffs.MultiSetAddDiff
- toString() - Method in class com.rpl.rama.diffs.MultiSetRemoveDiff
- toString() - Method in class com.rpl.rama.diffs.NewValueDiff
- toString() - Method in class com.rpl.rama.diffs.ResyncDiff
- toString() - Method in class com.rpl.rama.diffs.SequenceChangeDiff
- toString() - Method in class com.rpl.rama.diffs.SequenceIndexChangeDiff
- toString() - Method in class com.rpl.rama.diffs.SequenceIndexChangesDiff
- toString() - Method in class com.rpl.rama.diffs.SequenceIndexRemoveDiff
- toString() - Method in class com.rpl.rama.diffs.SequenceInsertDiff
- toString() - Method in class com.rpl.rama.diffs.SequenceInsertsDiff
- toString() - Method in class com.rpl.rama.diffs.SequenceReorderDiff
- toString() - Method in class com.rpl.rama.diffs.SetAddDiff
- toString() - Method in class com.rpl.rama.diffs.SetRemoveDiff
- toString() - Method in class com.rpl.rama.diffs.UngracefulTerminationDiff
- toString() - Method in class com.rpl.rama.diffs.UnknownDiff
- toString() - Method in class com.rpl.rama.MicrobatchParams
- transform(Path) - Method in interface com.rpl.rama.test.TestPState
-
Transforms PState with
Path
. - transform(T, Navigator.Next) - Method in interface com.rpl.rama.Navigator
-
Implements codepath for transform calls.
- transformed(Path) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to transformation of current value with given path.
- transformed(Path) - Static method in interface com.rpl.rama.Path
-
Navigates to transformation of current value with given path.
- TUPLE - Static variable in class com.rpl.rama.ops.Ops
-
Combines all input arguments into a
List
Example:Block.each(Ops.TUPLE, 1, 2, 3).out("*tuple")
U
- UngracefulTerminationDiff - Class in com.rpl.rama.diffs
-
Sent when the proxy has been terminated by Rama due to having too many failures.
- UngracefulTerminationDiff(Throwable) - Constructor for class com.rpl.rama.diffs.UngracefulTerminationDiff
- UngracefulTerminationDiff.Processor - Interface in com.rpl.rama.diffs
- unhandled() - Method in interface com.rpl.rama.diffs.Diff.Processor
- unify(String, String, String...) - Method in interface com.rpl.rama.Block.Impl
-
Attaches subsequent code to each of the anchors specified, merging computation flowing out of those nodes.
- unify(String, String, String...) - Static method in interface com.rpl.rama.Block
-
Attaches subsequent code to each of the anchors specified, merging computation flowing out of those nodes.
- unify(String, String, String...) - Method in interface com.rpl.rama.Case.Impl
-
Attaches subsequent code to each of the anchors specified, merging computation flowing out of those nodes.
- unify(String, String, String...) - Method in interface com.rpl.rama.SubSource.Impl
-
Attaches subsequent code to each of the anchors specified, merging computation flowing out of those nodes.
- UnknownDiff - Class in com.rpl.rama.diffs
-
Change between old and new values is unknown.
- UnknownDiff() - Constructor for class com.rpl.rama.diffs.UnknownDiff
- UnknownDiff.Processor - Interface in com.rpl.rama.diffs
- updateModule(RamaModule) - Method in interface com.rpl.rama.test.InProcessCluster
-
Update a module to a new version.
- updateModule(RamaModule, UpdateOptions) - Method in interface com.rpl.rama.test.InProcessCluster
-
Update a module to a new version.
- UpdateOptions - Interface in com.rpl.rama.test
-
Class for providing options to
InProcessCluster.updateModule(RamaModule, UpdateOptions)
- UpdateOptions.Impl - Interface in com.rpl.rama.test
V
- value - Variable in enum class com.rpl.rama.module.OffsetAgo
- valueOf(String) - Static method in enum class com.rpl.rama.AckLevel
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.rpl.rama.module.OffsetAgo
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.rpl.rama.ProxyState.Status
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class com.rpl.rama.AckLevel
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.rpl.rama.module.OffsetAgo
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.rpl.rama.ProxyState.Status
-
Returns an array containing the constants of this enum class, in the order they are declared.
- var - Variable in class com.rpl.rama.LoopVars.LoopVar
- var(String, Object) - Method in interface com.rpl.rama.LoopVars.Impl
-
Declare a var with initial value for first iteration of loop
- var(String, Object) - Method in class com.rpl.rama.LoopVars.LoopVarsCollector
- var(String, Object) - Static method in interface com.rpl.rama.LoopVars
-
Declare a var with initial value for first iteration of loop
- view(RamaFunction1<T0, R0>) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to result of applying given function to current value.
- view(RamaFunction1<T0, R0>) - Static method in interface com.rpl.rama.Path
-
Navigates to result of applying given function to current value.
- view(RamaFunction2<T0, T1, R0>, Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to result of applying given function to current value and provided arguments.
- view(RamaFunction2<T0, T1, R0>, Object) - Static method in interface com.rpl.rama.Path
-
Navigates to result of applying given function to current value and provided arguments.
- view(RamaFunction3<T0, T1, T2, R0>, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to result of applying given function to current value and provided arguments.
- view(RamaFunction3<T0, T1, T2, R0>, Object, Object) - Static method in interface com.rpl.rama.Path
-
Navigates to result of applying given function to current value and provided arguments.
- view(RamaFunction4<T0, T1, T2, T3, R0>, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to result of applying given function to current value and provided arguments.
- view(RamaFunction4<T0, T1, T2, T3, R0>, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Navigates to result of applying given function to current value and provided arguments.
- view(RamaFunction5<T0, T1, T2, T3, T4, R0>, Object, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to result of applying given function to current value and provided arguments.
- view(RamaFunction5<T0, T1, T2, T3, T4, R0>, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Navigates to result of applying given function to current value and provided arguments.
- view(RamaFunction6<T0, T1, T2, T3, T4, T5, R0>, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to result of applying given function to current value and provided arguments.
- view(RamaFunction6<T0, T1, T2, T3, T4, T5, R0>, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Navigates to result of applying given function to current value and provided arguments.
- view(RamaFunction7<T0, T1, T2, T3, T4, T5, T6, R0>, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to result of applying given function to current value and provided arguments.
- view(RamaFunction7<T0, T1, T2, T3, T4, T5, T6, R0>, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Navigates to result of applying given function to current value and provided arguments.
- view(RamaFunction8<T0, T1, T2, T3, T4, T5, T6, T7, R0>, Object, Object, Object, Object, Object, Object, Object) - Method in interface com.rpl.rama.Path.Impl
-
Navigates to result of applying given function to current value and provided arguments.
- view(RamaFunction8<T0, T1, T2, T3, T4, T5, T6, T7, R0>, Object, Object, Object, Object, Object, Object, Object) - Static method in interface com.rpl.rama.Path
-
Navigates to result of applying given function to current value and provided arguments.
- VOID - Static variable in interface com.rpl.rama.Navigator
- voided() - Static method in interface com.rpl.rama.Agg
-
Aggregates to "void" value.
- voidSetElem() - Method in interface com.rpl.rama.Path.Impl
-
Navigates to void element of set.
- voidSetElem() - Static method in interface com.rpl.rama.Path
-
Navigates to void element of set.
W
- waitForMicrobatchProcessedCount(String, String, int) - Method in interface com.rpl.rama.test.InProcessCluster
-
Block until specified microbatch topology has finished processing at least the specified number of depot records since the topology started.
- waitForMicrobatchProcessedCount(String, String, int, int) - Method in interface com.rpl.rama.test.InProcessCluster
-
Block until specified microbatch topology has finished processing at least the specified number of depot records since the topology started.
- walkExpanded(RamaFunction1) - Method in class com.rpl.rama.diffs.Diff
- walkExpanded(RamaFunction1) - Method in class com.rpl.rama.diffs.KeyChangeDiff
- walkExpanded(RamaFunction1) - Method in class com.rpl.rama.diffs.KeysDiff
- walkExpanded(RamaFunction1) - Method in class com.rpl.rama.diffs.KeysRemoveDiff
- walkExpanded(RamaFunction1) - Method in class com.rpl.rama.diffs.MultiDiff
- walkExpanded(RamaFunction1) - Method in class com.rpl.rama.diffs.MultiSetAddDiff
- walkExpanded(RamaFunction1) - Method in class com.rpl.rama.diffs.MultiSetRemoveDiff
- walkExpanded(RamaFunction1) - Method in class com.rpl.rama.diffs.SequenceChangeDiff
- walkExpanded(RamaFunction1) - Method in class com.rpl.rama.diffs.SequenceIndexChangeDiff
- walkExpanded(RamaFunction1) - Method in class com.rpl.rama.diffs.SequenceIndexChangesDiff
- walkExpanded(RamaFunction1) - Method in class com.rpl.rama.diffs.SequenceIndexRemoveDiff
- walkExpanded(RamaFunction1) - Method in class com.rpl.rama.diffs.SequenceInsertDiff
- walkExpanded(RamaFunction1) - Method in class com.rpl.rama.diffs.SequenceInsertsDiff
- walkExpanded(RamaFunction1) - Method in class com.rpl.rama.diffs.SequenceReorderDiff
- withoutSizeTracking() - Method in class com.rpl.rama.SubindexOptions.CapturedSubindexOptions
- withoutSizeTracking() - Method in interface com.rpl.rama.SubindexOptions.Impl
-
Disable automatic size tracking on this subindexed data structure.
- withoutSizeTracking() - Static method in interface com.rpl.rama.SubindexOptions
-
Disable automatic size tracking on this subindexed data structure.
- withPageSize(Object, Path) - Method in interface com.rpl.rama.Path.Impl
-
Pagination done by navigators in subpath use the specified page size.
- withPageSize(Object, Path) - Static method in interface com.rpl.rama.Path
-
Pagination done by navigators in subpath use the specified page size.
- WorkerManagedResource<T> - Class in com.rpl.rama.integration
-
Used for sharing resources across tasks in a worker
- WorkerManagedResource(String, TaskGlobalContext, Callable<T>) - Constructor for class com.rpl.rama.integration.WorkerManagedResource
Y
- yieldIfOvertime() - Method in interface com.rpl.rama.Block.Impl
-
Yield the task thread if current event is using too much time.
- yieldIfOvertime() - Static method in interface com.rpl.rama.Block
-
Yield the task thread if current event is using too much time.
- yieldIfOvertime() - Method in interface com.rpl.rama.Case.Impl
-
Yield the task thread if current event is using too much time.
- yieldIfOvertime() - Method in interface com.rpl.rama.SubSource.Impl
-
Yield the task thread if current event is using too much time.
Z
- zeroVal() - Method in interface com.rpl.rama.ops.RamaCombinerAgg
-
Returns result value if there is no input
All Classes and Interfaces|All Packages|Serialized Form