A B C D E F G H I J K L M N O P R S T U V W Y Z 
All Classes All Packages

A

aborted() - Method in class cz.o2.proxima.core.transaction.Response
Create response for aborted transaction.
aborted() - Method in class cz.o2.proxima.core.transaction.State
Move this state to State.Flags.ABORTED.
ABORTED - cz.o2.proxima.core.transaction.Response.Flags
 
ABORTED - cz.o2.proxima.core.transaction.State.Flags
 
absolute(String, String) - Method in class cz.o2.proxima.core.metrics.MetricFactory
 
AbsoluteMetric - Class in cz.o2.proxima.core.metrics
A metric with absolute value.
AbsoluteMetric(String, String) - Constructor for class cz.o2.proxima.core.metrics.AbsoluteMetric
 
AbstractAttributeWriter - Class in cz.o2.proxima.direct.core
Base class for AttributeWriters.
AbstractAttributeWriter(EntityDescriptor, URI) - Constructor for class cz.o2.proxima.direct.core.AbstractAttributeWriter
 
AbstractBulkAttributeWriter - Class in cz.o2.proxima.direct.core
Abstract implementation of BulkAttributeWriter.
AbstractBulkAttributeWriter(EntityDescriptor, URI) - Constructor for class cz.o2.proxima.direct.core.AbstractBulkAttributeWriter
 
AbstractBulkFileSystemAttributeWriter - Class in cz.o2.proxima.direct.io.bulkfs
An abstract parent class for BulkAttributeWriter.
AbstractBulkFileSystemAttributeWriter(EntityDescriptor, URI, FileSystem, NamingConvention, FileFormat, Context, long, long) - Constructor for class cz.o2.proxima.direct.io.bulkfs.AbstractBulkFileSystemAttributeWriter
 
AbstractBulkFileSystemAttributeWriter.Bulk - Class in cz.o2.proxima.direct.io.bulkfs
 
AbstractDataAccessor - Interface in cz.o2.proxima.core.storage.internal
Interface for all modules data accessors to extend.
AbstractDataAccessorFactory<OP extends DataOperator,​T extends AbstractDataAccessor> - Interface in cz.o2.proxima.core.storage.internal
Interface for all module data accessor factories to extend.
AbstractDataAccessorFactory.Accept - Enum in cz.o2.proxima.core.storage.internal
Marker for acceptance of given URI to this factory.
AbstractOnlineAttributeWriter - Class in cz.o2.proxima.direct.core
Abstract implementation of the OnlineAttributeWriter.
AbstractOnlineAttributeWriter(EntityDescriptor, URI) - Constructor for class cz.o2.proxima.direct.core.AbstractOnlineAttributeWriter
 
AbstractPubSubReader - Class in cz.o2.proxima.direct.io.pubsub
 
AbstractPubSubReader(EntityDescriptor, URI, PubSubAccessor, Context) - Constructor for class cz.o2.proxima.direct.io.pubsub.AbstractPubSubReader
 
AbstractPubSubWriter - Class in cz.o2.proxima.direct.io.pubsub
 
AbstractPubSubWriter(PubSubAccessor, Context) - Constructor for class cz.o2.proxima.direct.io.pubsub.AbstractPubSubWriter
 
AbstractStorage - Class in cz.o2.proxima.core.storage
A class that is super type of all data accessors.
AbstractStorage() - Constructor for class cz.o2.proxima.core.storage.AbstractStorage
 
AbstractStorage(EntityDescriptor, URI) - Constructor for class cz.o2.proxima.core.storage.AbstractStorage
 
AbstractStorage.SerializableAbstractStorage - Class in cz.o2.proxima.core.storage
An AbstractStorage that is legitimately Serializable.
AbstractWatermarkEstimator - Class in cz.o2.proxima.core.time
The watermark estimator base class.
AbstractWatermarkEstimator(WatermarkIdlePolicy) - Constructor for class cz.o2.proxima.core.time.AbstractWatermarkEstimator
 
accept(A, B) - Method in interface cz.o2.proxima.core.functional.BiConsumer
Apply action to first arguments.
accept(T) - Method in interface cz.o2.proxima.core.functional.Consumer
Apply action to given input.
ACCEPT - cz.o2.proxima.core.storage.internal.AbstractDataAccessorFactory.Accept
The URI is accepted.
ACCEPT_IF_NEEDED - cz.o2.proxima.core.storage.internal.AbstractDataAccessorFactory.Accept
The URI is accepted, if there is no other factory, that can accept this URI.
accepts(URI) - Method in class cz.o2.proxima.beam.core.direct.io.DirectDataAccessorFactory
 
accepts(URI) - Method in class cz.o2.proxima.beam.io.pubsub.PubSubDataAccessorFactory
 
accepts(URI) - Method in class cz.o2.proxima.beam.storage.TestStreamStorage
 
accepts(URI) - Method in interface cz.o2.proxima.core.storage.internal.AbstractDataAccessorFactory
Check if this factory can create accessors for given URI.
accepts(URI) - Method in class cz.o2.proxima.direct.core.DirectDataOperator.DelegateDataAccessorFactory
 
accepts(URI) - Method in class cz.o2.proxima.direct.core.StdoutStorage
 
accepts(URI) - Method in class cz.o2.proxima.direct.io.bigtable.BigTableStorage
 
accepts(URI) - Method in class cz.o2.proxima.direct.io.cassandra.CassandraStorageDescriptor
 
accepts(URI) - Method in class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchStorage
 
accepts(URI) - Method in class cz.o2.proxima.direct.io.gcloud.storage.GCloudStorageDescriptor
 
accepts(URI) - Method in class cz.o2.proxima.direct.io.hadoop.HadoopStorage
 
accepts(URI) - Method in class cz.o2.proxima.direct.io.hbase.HBaseStorageDescriptor
 
accepts(URI) - Method in class cz.o2.proxima.direct.io.http.HttpStorage
 
accepts(URI) - Method in class cz.o2.proxima.direct.io.kafka.KafkaStorage
 
accepts(URI) - Method in class cz.o2.proxima.direct.io.pubsub.PubSubStorage
 
accepts(URI) - Method in class cz.o2.proxima.direct.io.s3.S3StorageDescriptor
 
accepts(URI) - Method in class cz.o2.proxima.direct.jdbc.JdbcStorageDescriptor
 
ACCESS - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
ACCESSES - cz.o2.proxima.core.repository.Repository.Validate
Validate that families have correctly configured access patterns.
accessor - Variable in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubReader
 
accessor - Variable in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubWriter
 
AccessType - Interface in cz.o2.proxima.core.storage
Access type to attribute family.
add(HadoopPath) - Method in class cz.o2.proxima.direct.io.hadoop.HadoopPartition
 
add(String, Object) - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementMaterializer.ParquetColumnGroup
 
addAttribute(AttributeDescriptor<?>) - Method in class cz.o2.proxima.core.repository.AttributeFamilyDescriptor.Builder
 
addAttribute(AttributeDescriptor<?>) - Method in class cz.o2.proxima.core.repository.EntityDescriptor.Builder
 
addAttributes(RandomAccessReader, AttributeDescriptor<?>...) - Method in class cz.o2.proxima.direct.core.randomaccess.MultiAccessBuilder
Add specified attributes to be read with given reader.
addedDataOperator(DataOperator) - Method in class cz.o2.proxima.core.repository.ConfigRepository
 
addedDataOperator(DataOperator) - Method in class cz.o2.proxima.core.repository.Repository
Called when new DataOperator is created.
addFamily(AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.core.randomaccess.MultiAccessBuilder
Add specified family to be read with given reader.
addField(String, SchemaDescriptors.SchemaTypeDescriptor<?>) - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.StructureTypeDescriptor
Add Field into structure type.
addOutputs(List<StreamElement>) - Method in interface cz.o2.proxima.direct.server.transaction.TransactionContext.Transaction
 
afterNumCommits(int, CommitCallback) - Static method in interface cz.o2.proxima.direct.core.CommitCallback
Create new CommitCallback that will commit the delegate after numCommits successful commits as successful, or after first error as failed
ALL - cz.o2.proxima.core.repository.Repository.Validate
Turn on all validations.
ALL - cz.o2.proxima.core.repository.TransactionMode
Transactional support across different keys of either the same or different entities.
ALL - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
ALLOWED_LATENESS_MS - Static variable in class cz.o2.proxima.direct.io.blob.BlobStorageAccessor
Maximal allowed lateness to wait before segment is rolled.
ALLOWED_TIMESTAMP_SKEW - Static variable in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator
 
allowedParallelism() - Method in annotation type cz.o2.proxima.core.annotations.DeclaredThreadSafe
 
AndFilter(List<StorageFilter>) - Constructor for class cz.o2.proxima.core.storage.StorageFilter.AndFilter
 
apply() - Method in interface cz.o2.proxima.core.functional.Factory
Apply the factory function.
apply() - Method in interface cz.o2.proxima.core.functional.VoidConsumer
Call the function.
apply() - Method in interface cz.o2.proxima.core.repository.ConsumerNameFactory
Get consumer name
apply() - Method in interface cz.o2.proxima.core.repository.RepositoryFactory
Create new Repository
apply() - Method in class cz.o2.proxima.core.repository.RepositoryFactory.Compressed
 
apply() - Method in class cz.o2.proxima.core.repository.RepositoryFactory.LocalInstance
 
apply() - Method in class cz.o2.proxima.core.repository.RepositoryFactory.VersionedCaching
 
apply() - Method in interface cz.o2.proxima.direct.core.transaction.ServerTransactionManager.InitialSequenceIdPolicy
Retrieve an initial seed for sequential ID.
apply() - Method in class cz.o2.proxima.direct.core.transaction.ServerTransactionManager.InitialSequenceIdPolicy.Default
 
apply() - Method in interface cz.o2.proxima.direct.io.kafka.OffsetCommitter.Callback
 
apply(A, B) - Method in interface cz.o2.proxima.core.functional.BiFunction
 
apply(A, B) - Method in interface cz.o2.proxima.core.util.ExceptionUtils.ThrowingBiConsumer
 
apply(StreamElement) - Method in class cz.o2.proxima.core.storage.PassthroughFilter
 
apply(StreamElement) - Method in class cz.o2.proxima.core.storage.StorageFilter.AndFilter
 
apply(StreamElement) - Method in interface cz.o2.proxima.core.storage.StorageFilter
When returns false the input element is not stored in the storage and is discarded.
apply(StreamElement) - Method in class cz.o2.proxima.core.storage.StorageFilter.OrFilter
 
apply(StreamElement, ElementWiseTransformation.Collector<StreamElement>) - Method in interface cz.o2.proxima.core.transform.ElementWiseTransformation
Apply the transformation function.
apply(StreamElement, ElementWiseTransformation.Collector<StreamElement>) - Method in class cz.o2.proxima.core.transform.IdentityTransformation
 
apply(StreamElement, ElementWiseTransformation.Collector<StreamElement>) - Method in class cz.o2.proxima.core.transform.RenameTransformation
 
apply(F, S, T) - Method in interface cz.o2.proxima.core.functional.TriFunction
 
apply(IN) - Method in interface cz.o2.proxima.core.functional.UnaryFunction
Apply function and return result.
apply(IN) - Method in interface cz.o2.proxima.core.util.ExceptionUtils.ThrowingUnaryFunction
 
apply(String) - Static method in class cz.o2.proxima.core.util.CamelCase
Convert given string to camelCase with first letter upper case.
apply(String, boolean) - Static method in class cz.o2.proxima.core.util.CamelCase
Convert given string to camelCase.
apply(String, boolean, CamelCase.Characters) - Static method in class cz.o2.proxima.core.util.CamelCase
Convert given string to camelCase.
apply(String, CamelCase.Characters) - Static method in class cz.o2.proxima.core.util.CamelCase
Convert given string to camelCase with first letter upper case.
apply(PipelineOptions) - Method in interface cz.o2.proxima.beam.tools.groovy.BeamStreamProvider.RunnerRegistrar
 
apply(T) - Method in interface cz.o2.proxima.core.functional.UnaryPredicate
Retrieve value of the predicate for given input.
apply(T) - Method in interface cz.o2.proxima.core.util.ExceptionUtils.ThrowingConsumer
 
ApproxPercentileMetric - Class in cz.o2.proxima.core.metrics
An approximation of 1st, 10th, 30th, 50th, 70th, 90th and 99th percentile.
ApproxPercentileMetricMXBean - Interface in cz.o2.proxima.core.metrics
Percentile metric MX bean.
ARRAY - cz.o2.proxima.core.scheme.AttributeValueAccessor.Type
 
ARRAY - cz.o2.proxima.core.scheme.AttributeValueType
 
arrays(SchemaDescriptors.SchemaTypeDescriptor<T>) - Static method in class cz.o2.proxima.core.scheme.SchemaDescriptors
ArrayTypeDescriptor(SchemaDescriptors.SchemaTypeDescriptor<T>) - Constructor for class cz.o2.proxima.core.scheme.SchemaDescriptors.ArrayTypeDescriptor
 
ArrayValueAccessorImpl(AttributeValueAccessor<T, V>) - Constructor for class cz.o2.proxima.core.scheme.AttributeValueAccessors.ArrayValueAccessorImpl
 
as(Class<T>) - Method in interface cz.o2.proxima.core.transform.DataOperatorAware
Convert this transformation to a more (DataOperator) specific one.
asArrayTypeDescriptor() - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.ArrayTypeDescriptor
 
asArrayTypeDescriptor() - Method in interface cz.o2.proxima.core.scheme.SchemaDescriptors.SchemaTypeDescriptor
Return current type descriptor as SchemaDescriptors.ArrayTypeDescriptor.
asContextual() - Method in interface cz.o2.proxima.core.transform.ProxyTransform
Convert this proxy to contextual transform.
asContextualTransform() - Method in interface cz.o2.proxima.core.transform.Transformation
Convert this transformation to (operator specific) contextual transform.
asElementWise() - Method in interface cz.o2.proxima.core.transform.ProxyTransform
Convert this proxy to element wise transform.
asElementWiseTransform() - Method in interface cz.o2.proxima.core.transform.Transformation
Convert this transformation to element wise (stateless).
asEnumTypeDescriptor() - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.EnumTypeDescriptor
 
asEnumTypeDescriptor() - Method in interface cz.o2.proxima.core.scheme.SchemaDescriptors.SchemaTypeDescriptor
Return current type as SchemaDescriptors.EnumTypeDescriptor.
asFactory() - Method in class cz.o2.proxima.core.repository.Repository
Convert this repository to Serializable factory.
asFactory() - Method in interface cz.o2.proxima.direct.core.AttributeWriterBase
Convert instance of this writer to AttributeWriterBase.Factory suitable for serialization.
asFactory() - Method in interface cz.o2.proxima.direct.core.batch.BatchLogReader
Convert instance of this reader to BatchLogReader.Factory suitable for serialization.
asFactory() - Method in interface cz.o2.proxima.direct.core.BulkAttributeWriter
 
asFactory() - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Convert instance of this reader to CommitLogReader.Factory suitable for serialization.
asFactory() - Method in class cz.o2.proxima.direct.core.commitlog.CommitLogReaders.LimitedCommitLogReader
 
asFactory() - Method in interface cz.o2.proxima.direct.core.OnlineAttributeWriter
 
asFactory() - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
Convert instance of this reader to RandomAccessReader.Factory suitable for serialization.
asFactory() - Method in class cz.o2.proxima.direct.core.transaction.TransactionalCachedView
 
asFactory() - Method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter
 
asFactory() - Method in interface cz.o2.proxima.direct.core.view.CachedView
Convert instance of this view to CachedView.Factory suitable for serialization.
asFactory() - Method in class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
asFactory() - Method in class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchWriter
 
asFactory() - Method in class cz.o2.proxima.direct.io.gcloud.storage.BulkGCloudStorageWriter
 
asFactory() - Method in class cz.o2.proxima.direct.io.gcloud.storage.GCloudLogReader
 
asFactory() - Method in class cz.o2.proxima.direct.io.hadoop.HadoopBatchLogReader
 
asFactory() - Method in class cz.o2.proxima.direct.io.hadoop.HadoopBulkAttributeWriter
 
asFactory() - Method in class cz.o2.proxima.direct.io.hbase.RandomHBaseReader
 
asFactory() - Method in class cz.o2.proxima.direct.io.http.HttpWriter
 
asFactory() - Method in class cz.o2.proxima.direct.io.http.opentsdb.OpenTsdbWriter
 
asFactory() - Method in class cz.o2.proxima.direct.io.http.WebsocketReader
 
asFactory() - Method in class cz.o2.proxima.direct.io.kafka.KafkaLogReader
 
asFactory() - Method in class cz.o2.proxima.direct.io.kafka.KafkaWriter
 
asFactory() - Method in class cz.o2.proxima.direct.io.pubsub.PubSubBulkReader
 
asFactory() - Method in class cz.o2.proxima.direct.io.s3.BulkS3Writer
 
asFactory() - Method in class cz.o2.proxima.direct.io.s3.S3LogReader
 
asFactory() - Method in class cz.o2.proxima.direct.jdbc.JdbcBatchLogReader
 
asFactory() - Method in class cz.o2.proxima.direct.jdbc.JdbcOnlineAttributeReader
 
asFactory() - Method in class cz.o2.proxima.direct.jdbc.JdbcOnlineAttributeWriter
 
asFactory() - Method in class cz.o2.proxima.flink.core.batch.OffsetTrackingBatchLogReader
 
asJsonValue(T) - Method in interface cz.o2.proxima.core.scheme.ValueSerializer
Convert given value to JSON representation (including quotation).
asKeyValues(EntityDescriptor, List<AttributeDescriptor<?>>, long, ResultSet) - Method in interface cz.o2.proxima.direct.jdbc.Converter
Convert single row of result to KeyValues.
asOnIdleContext(WatermarkSupplier) - Static method in class cz.o2.proxima.direct.core.commitlog.ObserverUtils
 
asOnNextContext(CommitLogObserver.OffsetCommitter, Offset) - Static method in class cz.o2.proxima.direct.core.commitlog.ObserverUtils
 
asPrimitiveTypeDescriptor() - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.ArrayTypeDescriptor
 
asPrimitiveTypeDescriptor() - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.PrimitiveTypeDescriptor
 
asPrimitiveTypeDescriptor() - Method in interface cz.o2.proxima.core.scheme.SchemaDescriptors.SchemaTypeDescriptor
Return current type descriptor as SchemaDescriptors.PrimitiveTypeDescriptor
asProxy() - Method in interface cz.o2.proxima.core.repository.AttributeDescriptor
Convert this object to AttributeProxyDescriptor iff AttributeDescriptor.isProxy() returns true.
asProxy() - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor
 
asRepartitionContext(Collection<Partition>) - Static method in class cz.o2.proxima.direct.core.commitlog.ObserverUtils
 
asResidual() - Method in class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker.OffsetRange
 
assertSingleton() - Method in class cz.o2.proxima.direct.transaction.manager.TransactionLogObserver
 
assign(Collection<Partition>) - Method in interface cz.o2.proxima.direct.core.view.CachedView
Assign and make given partitions accessible by random reads.
assign(Collection<Partition>, BiConsumer<StreamElement, Pair<Long, Object>>) - Method in interface cz.o2.proxima.direct.core.view.CachedView
Assign and make given partitions accessible by random reads.
assign(Collection<Partition>, BiConsumer<StreamElement, Pair<Long, Object>>, Duration) - Method in interface cz.o2.proxima.direct.core.view.CachedView
Assign and make given partitions accessible by random reads.
assign(Collection<Partition>, BiConsumer<StreamElement, Pair<Long, Object>>, Duration) - Method in class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
assign(Collection<Partition>, Duration) - Method in interface cz.o2.proxima.direct.core.view.CachedView
Assign and make given partitions accessible by random reads.
assignEventTime(Closure<Long>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Assign event time to elements.
assignEventTime(Closure<Long>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
 
assignEventTime(String, Closure<Long>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Assign event time to elements.
assignEventTime(String, Closure<Long>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
 
AssignEventTime<T> - Class in cz.o2.proxima.beam.core.transforms
 
ASSIGNMENT_TIMEOUT_MS - Static variable in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
Timeout in milliseconds, that consumer should wait for group assignment before throwing an exception.
assignWindow(Instant) - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.DaysWindows
 
assignWindow(Instant) - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.MonthsWindows
 
assignWindow(Instant) - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.YearsWindows
 
asStreamElements(RepositoryProvider, EntityDescriptor, Closure<CharSequence>, Closure<CharSequence>, Closure<V>, Closure<Long>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Convert elements to StreamElements.
asStreamElements(RepositoryProvider, EntityDescriptor, Closure<CharSequence>, Closure<CharSequence>, Closure<V>, Closure<Long>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
 
asString(String) - Method in class cz.o2.proxima.direct.io.cassandra.StringConverter.DefaultConverter
 
asString(Date) - Method in class cz.o2.proxima.direct.io.cassandra.DateToLongConverter
 
asString(T) - Method in interface cz.o2.proxima.direct.io.cassandra.StringConverter
Convert type to string.
asStructureTypeDescriptor() - Method in interface cz.o2.proxima.core.scheme.SchemaDescriptors.SchemaTypeDescriptor
Return current type descriptor as SchemaDescriptors.StructureTypeDescriptor.
asStructureTypeDescriptor() - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.StructureTypeDescriptor
 
asUnbounded() - Method in interface cz.o2.proxima.tools.groovy.Stream
Process this stream as it was unbounded stream.
asUnbounded() - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
 
ATTRIBUTE - cz.o2.proxima.core.repository.TransactionMode
Transactional support within the same attribute (i.e.
ATTRIBUTE - cz.o2.proxima.direct.core.randomaccess.RandomAccessReader.Listing
 
ATTRIBUTE_FAMILIES - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
AttributeDescriptor<T> - Interface in cz.o2.proxima.core.repository
An interface describing each attribute.
AttributeDescriptor.Builder - Class in cz.o2.proxima.core.repository
 
AttributeDescriptorBase<T> - Class in cz.o2.proxima.core.repository
AttributeDescriptorBase(String, AttributeDescriptor<T>, AttributeDescriptor<T>, boolean, URI, ValueSerializer<T>) - Constructor for class cz.o2.proxima.core.repository.AttributeDescriptorBase
 
AttributeDescriptorBase(String, String, URI, ValueSerializer<T>, boolean, TransactionMode) - Constructor for class cz.o2.proxima.core.repository.AttributeDescriptorBase
 
AttributeDescriptorCoder - Class in cz.o2.proxima.beam.core.io
 
AttributeDescriptorImpl<T> - Class in cz.o2.proxima.core.repository
Descriptor of attribute of entity.
AttributeDescriptorProvider<T> - Interface in cz.o2.proxima.tools.groovy
Provider of AttributeDescriptor.
AttributeFamilyDescriptor - Class in cz.o2.proxima.core.repository
A family of attributes with the same storage.
AttributeFamilyDescriptor.Builder - Class in cz.o2.proxima.core.repository
 
AttributeFamilyProxyDataAccessor - Class in cz.o2.proxima.beam.core
AttributeFamilyProxyDescriptor - Class in cz.o2.proxima.core.repository
Proxy attribute family applying transformations of attributes to and from private space to public space.
AttributeProxyDescriptor<T> - Class in cz.o2.proxima.core.repository
Proxy to another attribute.
ATTRIBUTES - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
AttributeValueAccessor<InputT,​OutputT> - Interface in cz.o2.proxima.core.scheme
Interface for value accessors allowed create and get value of attribute
AttributeValueAccessor.Type - Enum in cz.o2.proxima.core.scheme
Accessor type
AttributeValueAccessors - Class in cz.o2.proxima.core.scheme
Classes and interfaces allows manipulation with attribute value.
AttributeValueAccessors.ArrayValueAccessor<T,​V> - Interface in cz.o2.proxima.core.scheme
Accessor for manipulation with SchemaDescriptors.ArrayTypeDescriptor.
AttributeValueAccessors.ArrayValueAccessorImpl<T,​V> - Class in cz.o2.proxima.core.scheme
AttributeValueAccessors.PrimitiveValueAccessor<T,​V> - Interface in cz.o2.proxima.core.scheme
Accessor for manipulation with SchemaDescriptors.PrimitiveTypeDescriptor.
AttributeValueAccessors.PrimitiveValueAccessorImpl<T,​V> - Class in cz.o2.proxima.core.scheme
Default implementation of AttributeValueAccessors.PrimitiveValueAccessor which use UnaryFunction to conversions.
AttributeValueAccessors.StructureValue - Interface in cz.o2.proxima.core.scheme
Interface represents value for AttributeValueAccessors.StructureValueAccessor.
AttributeValueAccessors.StructureValueAccessor<T> - Interface in cz.o2.proxima.core.scheme
 
AttributeValueAccessors.StructureValueImpl - Class in cz.o2.proxima.core.scheme
Default implementation of AttributeValueAccessors.StructureValueAccessor delegates methods to Map.
AttributeValueType - Enum in cz.o2.proxima.core.scheme
Possible attribute and field types
AttributeWriterBase - Interface in cz.o2.proxima.direct.core
Base interface for OnlineAttributeWriter and BulkAttributeWriter.
AttributeWriterBase.Factory<W extends AttributeWriterBase> - Interface in cz.o2.proxima.direct.core
Base interface for factories in implementing classes.
AttributeWriterBase.Type - Enum in cz.o2.proxima.direct.core
 
AUTO_COMMIT_INTERVAL_MS - Static variable in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
Auto commit interval in milliseconds.
average(Closure<Double>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Average elements of stream.
average(String, Closure<Double>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Average elements of stream.
averageByKey(Closure<K>, Closure<Double>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Average elements of stream by key.
averageByKey(String, Closure<K>, Closure<Double>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Average elements of stream by key.
AvroSerializer<T extends org.apache.avro.generic.GenericContainer> - Class in cz.o2.proxima.scheme.avro
Basic Avro serializer.
AvroSerializer(Schema) - Constructor for class cz.o2.proxima.scheme.avro.AvroSerializer
 
AvroSerializerFactory - Class in cz.o2.proxima.scheme.avro
Avro serializer factory for manipulate with SpecificRecords
AvroSerializerFactory() - Constructor for class cz.o2.proxima.scheme.avro.AvroSerializerFactory
 

B

BATCH_SNAPSHOT - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
BATCH_UPDATES - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
BatchLogObserver - Interface in cz.o2.proxima.direct.core.batch
Batch observer of data.
BatchLogObserver.OnNextContext - Interface in cz.o2.proxima.direct.core.batch
BatchLogObservers - Class in cz.o2.proxima.direct.core.batch
Utility class related to BatchLogObservers.
BatchLogRead - Class in cz.o2.proxima.beam.core.direct.io
A PTransform that reads from a BatchLogReader using splittable DoFn.
BatchLogRead.BatchLogReadOptionsFactory - Class in cz.o2.proxima.beam.core.direct.io
 
BatchLogRead.BatchLogReadPipelineOptions - Interface in cz.o2.proxima.beam.core.direct.io
 
BatchLogReader - Interface in cz.o2.proxima.direct.core.batch
Reader of batch data stored in batch storage.
BatchLogReader.Factory<T extends BatchLogReader> - Interface in cz.o2.proxima.direct.core.batch
Serializable factory for BatchLogReader.
BatchLogReaders - Class in cz.o2.proxima.direct.core.batch
Class constructing various BatchLogReaders.
BatchLogReaders.ForwardingBatchLogObserver - Class in cz.o2.proxima.direct.core.batch
 
BatchLogReadOptionsFactory() - Constructor for class cz.o2.proxima.beam.core.direct.io.BatchLogRead.BatchLogReadOptionsFactory
 
BatchLogSourceFunction<OutputT> - Class in cz.o2.proxima.flink.core
 
BatchLogSourceFunction(RepositoryFactory, List<AttributeDescriptor<?>>, ResultExtractor<OutputT>) - Constructor for class cz.o2.proxima.flink.core.BatchLogSourceFunction
 
BatchRestrictionTracker - Class in cz.o2.proxima.beam.core.direct.io
A RestrictionTracker for Offsets read from CommitLogReader
BatchRestrictionTracker.PartitionList - Class in cz.o2.proxima.beam.core.direct.io
 
BeamDataOperator - Class in cz.o2.proxima.beam.core
A DataOperator for Apache Beam transformations.
BeamDataOperatorFactory - Class in cz.o2.proxima.beam.core
BeamDataOperatorFactory() - Constructor for class cz.o2.proxima.beam.core.BeamDataOperatorFactory
 
BeamProxyTransform - Class in cz.o2.proxima.beam.core
Transform applicable on proxied attributes in apply section.
BeamProxyTransform() - Constructor for class cz.o2.proxima.beam.core.BeamProxyTransform
 
BeamStreamProvider - Class in cz.o2.proxima.beam.tools.groovy
A StreamProvider for groovy tools based on beam.
BeamStreamProvider() - Constructor for class cz.o2.proxima.beam.tools.groovy.BeamStreamProvider
 
BeamStreamProvider.Default - Class in cz.o2.proxima.beam.tools.groovy
 
BeamStreamProvider.RunnerRegistrar - Interface in cz.o2.proxima.beam.tools.groovy
 
begin() - Method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter
 
begin(Rpc.BeginTransactionRequest, StreamObserver<Rpc.BeginTransactionResponse>) - Method in class cz.o2.proxima.direct.server.RetrieveService
 
begin(String) - Method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter
 
begin(String, List<KeyAttribute>) - Method in interface cz.o2.proxima.direct.core.transaction.ClientTransactionManager
Initialize (possibly) new transaction.
begin(String, List<KeyAttribute>) - Method in class cz.o2.proxima.direct.core.transaction.TransactionResourceManager
Initialize new transaction.
beginningOnDay(int) - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.MonthsWindows
 
beginningOnDay(int, int) - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.YearsWindows
 
BiConsumer<A,​B> - Interface in cz.o2.proxima.core.functional
Apply action to two input elements.
BiFunction<A,​B,​OUT> - Interface in cz.o2.proxima.core.functional
Binary function of two arguments.
BigTableStorage - Class in cz.o2.proxima.direct.io.bigtable
Storage descriptor for bigtable:// URIs.
BigTableStorage() - Constructor for class cz.o2.proxima.direct.io.bigtable.BigTableStorage
 
blob(boolean) - Static method in interface cz.o2.proxima.direct.io.bulkfs.FileFormat
Create blob file format with specified FileSystem as root.
BlobBase - Interface in cz.o2.proxima.direct.io.blob
Generic descriptor of blob in any blob store (e.g.
BlobLogReader<BlobT extends BlobBase,​BlobPathT extends BlobPath<BlobT>> - Class in cz.o2.proxima.direct.io.blob
BatchLogReader for blob storages.
BlobLogReader(BlobStorageAccessor, Context) - Constructor for class cz.o2.proxima.direct.io.blob.BlobLogReader
 
BlobLogReader.ThrowingRunnable - Interface in cz.o2.proxima.direct.io.blob
 
BlobPath<BlobT extends BlobBase> - Class in cz.o2.proxima.direct.io.blob
A Path representation of a remote blob.
BlobPath(FileSystem, BlobT) - Constructor for class cz.o2.proxima.direct.io.blob.BlobPath
 
BlobStorageAccessor - Class in cz.o2.proxima.direct.io.blob
A DataAccessor for blob storages.
BlobStorageAccessor(AttributeFamilyDescriptor) - Constructor for class cz.o2.proxima.direct.io.blob.BlobStorageAccessor
 
BOOLEAN - cz.o2.proxima.core.scheme.AttributeValueType
 
booleans() - Static method in class cz.o2.proxima.core.scheme.SchemaDescriptors
BoundedOutOfOrdernessWatermarkEstimator - Class in cz.o2.proxima.direct.core.time
This estimators generates watermarks assuming that elements arrive out of order, but only to a certain degree defined by configuration: watermark.max-out-of-orderness.
BoundedOutOfOrdernessWatermarkEstimator.Builder - Class in cz.o2.proxima.direct.core.time
BoundedOutOfOrdernessWatermarkEstimator.Factory - Class in cz.o2.proxima.direct.core.time
BoundedPartition - Class in cz.o2.proxima.direct.core.batch
Bounded implementation of Partition.
BoundedPartition(int) - Constructor for class cz.o2.proxima.direct.core.batch.BoundedPartition
 
BoundedPartition(int, long) - Constructor for class cz.o2.proxima.direct.core.batch.BoundedPartition
 
BufferUntilCheckpoint<T> - Class in cz.o2.proxima.beam.core.transforms
Identity transformation which ensures exactly-once output.
BufferUntilCheckpoint() - Constructor for class cz.o2.proxima.beam.core.transforms.BufferUntilCheckpoint
 
build() - Method in class cz.o2.proxima.core.repository.AttributeDescriptor.Builder
 
build() - Method in class cz.o2.proxima.core.repository.AttributeFamilyDescriptor.Builder
 
build() - Method in class cz.o2.proxima.core.repository.ConfigRepository.Builder
 
build() - Method in class cz.o2.proxima.core.repository.EntityDescriptor.Builder
 
build() - Method in class cz.o2.proxima.direct.core.randomaccess.MultiAccessBuilder
Create RandomAccessReader for attributes and/or families specified in this builder.
build() - Method in class cz.o2.proxima.direct.core.time.BoundedOutOfOrdernessWatermarkEstimator.Builder
 
build() - Method in class cz.o2.proxima.direct.core.time.ProcessingTimeWatermarkEstimator.Builder
 
build() - Method in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator.Builder
 
Builder() - Constructor for class cz.o2.proxima.core.repository.EntityDescriptor.Builder
 
bulk() - Method in interface cz.o2.proxima.direct.core.AttributeWriterBase
Case this to BulkAttributeWriter.
BULK - cz.o2.proxima.direct.core.AttributeWriterBase.Type
 
BULK_SIZE - Static variable in class cz.o2.proxima.direct.server.metrics.Metrics
 
BulkAttributeWriter - Interface in cz.o2.proxima.direct.core
Writer for attribute values.
BulkAttributeWriter.Factory<T extends BulkAttributeWriter> - Interface in cz.o2.proxima.direct.core
Serializable factory for BulkAttributeWriter.
BulkBlobWriter<BlobT extends BlobBase,​AccessorT extends BlobStorageAccessor> - Class in cz.o2.proxima.direct.io.blob
BulkAttributeWriter for blob storages.
BulkBlobWriter(AccessorT, Context) - Constructor for class cz.o2.proxima.direct.io.blob.BulkBlobWriter
 
BulkGCloudStorageWriter - Class in cz.o2.proxima.direct.io.gcloud.storage
BulkAttributeWriter for gcloud storage.
BulkGCloudStorageWriter(GCloudStorageAccessor, Context) - Constructor for class cz.o2.proxima.direct.io.gcloud.storage.BulkGCloudStorageWriter
 
BulkS3Writer - Class in cz.o2.proxima.direct.io.s3
BulkAttributeWriter for gcloud storage.
BulkS3Writer(S3Accessor, Context) - Constructor for class cz.o2.proxima.direct.io.s3.BulkS3Writer
 
BYTE - cz.o2.proxima.core.scheme.AttributeValueType
 
bytes() - Static method in class cz.o2.proxima.core.scheme.SchemaDescriptors
BytesSerializer - Class in cz.o2.proxima.core.scheme
Validator of bytes scheme.
BytesSerializer() - Constructor for class cz.o2.proxima.core.scheme.BytesSerializer
 

C

cache(StreamElement) - Method in interface cz.o2.proxima.direct.core.view.CachedView
Cache given StreamElement into local cache without writing it to the underlying writer.
cache(StreamElement) - Method in class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
CacheableCqlFactory - Class in cz.o2.proxima.direct.io.cassandra
A cache for prepared CQL statements.
CacheableCqlFactory() - Constructor for class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
 
CACHED_VIEW - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
CachedView - Interface in cz.o2.proxima.direct.core.view
A view of commit-log that caches (and potentially checkpoints) data from partitions and makes in random accessible.
CachedView.Factory - Interface in cz.o2.proxima.direct.core.view
Serializable factory for CachedView.
caching(RepositoryFactory, Repository) - Static method in interface cz.o2.proxima.core.repository.RepositoryFactory
 
calendarWindow(String, int, TimeZone) - Method in interface cz.o2.proxima.tools.groovy.Stream
Create calendar-based windowed stream.
CalendarWindows - Class in cz.o2.proxima.beam.core.transforms
Fork of Beam's CalendarWindows.
CalendarWindows() - Constructor for class cz.o2.proxima.beam.core.transforms.CalendarWindows
 
CalendarWindows.DaysWindows - Class in cz.o2.proxima.beam.core.transforms
A WindowFn that windows elements into periods measured by days.
CalendarWindows.MonthsWindows - Class in cz.o2.proxima.beam.core.transforms
A WindowFn that windows elements into periods measured by months.
CalendarWindows.YearsWindows - Class in cz.o2.proxima.beam.core.transforms
A WindowFn that windows elements into periods measured by years.
CamelCase - Class in cz.o2.proxima.core.util
Transform string to camel case.
CamelCase.Characters - Enum in cz.o2.proxima.core.util
 
cancel() - Method in class cz.o2.proxima.direct.core.batch.TerminationContext
canCreateCachedView() - Method in interface cz.o2.proxima.core.storage.AccessType
 
canProvideTransactionSerializer() - Method in class cz.o2.proxima.core.scheme.JavaSerializer
 
canProvideTransactionSerializer() - Method in interface cz.o2.proxima.core.scheme.ValueSerializerFactory
 
canProvideTransactionSerializer() - Method in class cz.o2.proxima.scheme.proto.ProtoSerializerFactory
 
canRandomRead() - Method in interface cz.o2.proxima.core.storage.AccessType
 
canReadBatchSnapshot() - Method in interface cz.o2.proxima.core.storage.AccessType
 
canReadBatchUpdates() - Method in interface cz.o2.proxima.core.storage.AccessType
 
canReadCommitLog() - Method in interface cz.o2.proxima.core.storage.AccessType
 
CassandraDBAccessor - Class in cz.o2.proxima.direct.io.cassandra
AttributeWriter for Apache Cassandra.
CassandraDBAccessor(EntityDescriptor, URI, Map<String, Object>) - Constructor for class cz.o2.proxima.direct.io.cassandra.CassandraDBAccessor
 
CassandraPartition - Class in cz.o2.proxima.direct.io.cassandra
A Partition in Cassandra.
CassandraPartition(int, long, long, long, long, boolean) - Constructor for class cz.o2.proxima.direct.io.cassandra.CassandraPartition
 
CassandraStorageDescriptor - Class in cz.o2.proxima.direct.io.cassandra
Storage descriptor for Apache Cassandra.
CassandraStorageDescriptor() - Constructor for class cz.o2.proxima.direct.io.cassandra.CassandraStorageDescriptor
 
CFG_DEFAULT_ALLOWED_TIMESTAMP_SKEW - Static variable in class cz.o2.proxima.direct.io.pubsub.PubSubStorage
 
CFG_DEFAULT_MAX_ACK_DEADLINE - Static variable in class cz.o2.proxima.direct.io.pubsub.PubSubStorage
 
CFG_DEFAULT_SUBSCRIPTION_ACK_DEADLINE - Static variable in class cz.o2.proxima.direct.io.pubsub.PubSubStorage
 
CFG_DEFAULT_SUBSCRIPTION_AUTO_CREATE - Static variable in class cz.o2.proxima.direct.io.pubsub.PubSubStorage
 
CFG_DEFAULT_WATERMARK_ESTIMATE_DURATION - Static variable in class cz.o2.proxima.direct.io.pubsub.PubSubStorage
 
CFG_ENABLE_CHECKPOINT_PARTITION_MERGE - Static variable in class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource
 
CFG_ESTIMATOR_FACTORY - Static variable in class cz.o2.proxima.direct.core.time.WatermarkConfiguration
 
CFG_IDLE_POLICY_FACTORY - Static variable in class cz.o2.proxima.direct.core.time.WatermarkConfiguration
 
CFG_IGNORE_ERRORS - Static variable in class cz.o2.proxima.direct.server.Constants
 
CFG_MAX_ACCEPTABLE_UPDATE_AGE_MS - Static variable in class cz.o2.proxima.core.utils.zookeeper.ZKGlobalWatermarkTracker
 
CFG_MAX_ACK_DEADLINE - Static variable in class cz.o2.proxima.direct.io.pubsub.PubSubAccessor
 
CFG_NAME - Static variable in class cz.o2.proxima.core.utils.zookeeper.ZKGlobalWatermarkTracker
 
CFG_NUM_THREADS - Static variable in class cz.o2.proxima.direct.server.Constants
 
CFG_PORT - Static variable in class cz.o2.proxima.direct.server.Constants
 
CFG_PREFIX - Static variable in class cz.o2.proxima.direct.core.time.WatermarkConfiguration
 
CFG_REPLICATION_CONSUMER_NAME_GENERATOR - Static variable in class cz.o2.proxima.core.repository.AttributeFamilyDescriptor
 
CFG_SUBSCRIPTION_ACK_DEADLINE - Static variable in class cz.o2.proxima.direct.io.pubsub.PubSubAccessor
 
CFG_SUBSCRIPTION_AUTOCREATE - Static variable in class cz.o2.proxima.direct.io.pubsub.PubSubAccessor
 
CFG_TIME_PROVIDER - Static variable in class cz.o2.proxima.core.utils.zookeeper.ZKGlobalWatermarkTracker
 
check() - Method in interface cz.o2.proxima.tools.groovy.StreamProvider.TerminatePredicate
 
checkDone() - Method in class cz.o2.proxima.beam.core.direct.io.BatchRestrictionTracker
 
checkDone() - Method in class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker
 
CheckpointCoder() - Constructor for class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource.CheckpointCoder
 
ChildFirstURLClassLoader(URL[], ClassLoaders.ChildLayerFirstClassLoader) - Constructor for class cz.o2.proxima.core.util.internal.ClassLoaders.ChildFirstURLClassLoader
 
ChildLayerFirstClassLoader(ModuleFinder, ClassLoader) - Constructor for class cz.o2.proxima.core.util.internal.ClassLoaders.ChildLayerFirstClassLoader
 
classDef() - Method in interface cz.o2.proxima.core.generator.OperatorGenerator
Retrieve class definition for the subclass.
ClassLoaders - Class in cz.o2.proxima.core.util.internal
 
ClassLoaders.ChildFirstURLClassLoader - Class in cz.o2.proxima.core.util.internal
 
ClassLoaders.ChildLayerFirstClassLoader - Class in cz.o2.proxima.core.util.internal
 
ClassLoaders.ContextLoaderFence - Class in cz.o2.proxima.core.util.internal
 
Classpath - Class in cz.o2.proxima.core.util
Classpath related utilities.
clear() - Method in class cz.o2.proxima.core.scheme.AttributeValueAccessors.StructureValueImpl
 
clear() - Method in class cz.o2.proxima.direct.io.kafka.OffsetCommitter
Clear completely all mappings.
clear(ID, long) - Method in class cz.o2.proxima.direct.io.kafka.OffsetCommitter
Clear all records for given topic partition and offset.
clearAttributes() - Method in class cz.o2.proxima.core.repository.AttributeFamilyDescriptor.Builder
 
clearCache() - Method in class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
Clear the cache (e.g.
ClientTransactionManager - Interface in cz.o2.proxima.direct.core.transaction
 
clone(T) - Static method in class cz.o2.proxima.core.util.SerializableUtils
Clone given object using Java serialization.
close() - Method in class cz.o2.proxima.beam.core.BeamDataOperator
 
close() - Method in class cz.o2.proxima.beam.tools.groovy.BeamStreamProvider
 
close() - Method in interface cz.o2.proxima.core.repository.DataOperator
 
close() - Method in interface cz.o2.proxima.core.storage.commitlog.Partitioner
Close the partitioner after usage.
close() - Method in interface cz.o2.proxima.core.storage.ThroughputLimiter
 
close() - Method in class cz.o2.proxima.core.storage.ThroughputLimiter.NoOpThroughputLimiter
 
close() - Method in class cz.o2.proxima.core.storage.watermark.GlobalWatermarkThroughputLimiter
 
close() - Method in class cz.o2.proxima.core.util.internal.ClassLoaders.ContextLoaderFence
 
close() - Method in class cz.o2.proxima.direct.client.IngestClient
 
close() - Method in class cz.o2.proxima.direct.core.AbstractOnlineAttributeWriter
 
close() - Method in interface cz.o2.proxima.direct.core.AttributeWriterBase
Close allocated resources of this writer.
close() - Method in interface cz.o2.proxima.direct.core.batch.ObserveHandle
Stop the consumption.
close() - Method in class cz.o2.proxima.direct.core.batch.TerminationContext
 
close() - Method in interface cz.o2.proxima.direct.core.commitlog.ObserveHandle
Stop the consumption.
close() - Method in class cz.o2.proxima.direct.core.DirectDataOperator
Close the operator and release all allocated resources.
close() - Method in interface cz.o2.proxima.direct.core.transaction.ClientTransactionManager
 
close() - Method in interface cz.o2.proxima.direct.core.transaction.ServerTransactionManager
 
close() - Method in class cz.o2.proxima.direct.core.transaction.TransactionalCachedView
 
close() - Method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter
 
close() - Method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.Transaction
 
close() - Method in class cz.o2.proxima.direct.core.transaction.TransactionCommitTransformation
 
close() - Method in class cz.o2.proxima.direct.core.transaction.TransactionResourceManager
 
close() - Method in interface cz.o2.proxima.direct.core.view.CachedView
 
close() - Method in class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
close() - Method in class cz.o2.proxima.direct.io.blob.BulkBlobWriter
 
close() - Method in class cz.o2.proxima.direct.io.bulkfs.AbstractBulkFileSystemAttributeWriter
 
close() - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.ProximaParquetReader
 
close() - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.ProximaParquetWriter
 
close() - Method in interface cz.o2.proxima.direct.io.bulkfs.Reader
 
close() - Method in interface cz.o2.proxima.direct.io.bulkfs.Writer
Close and flush the writer to target FileSystem.
close() - Method in class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchWriter
 
close() - Method in class cz.o2.proxima.direct.io.hbase.RandomHBaseReader
 
close() - Method in class cz.o2.proxima.direct.io.http.HttpWriter
 
close() - Method in class cz.o2.proxima.direct.io.kafka.KafkaWriter
 
close() - Method in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubWriter
 
close() - Method in class cz.o2.proxima.direct.jdbc.JdbcOnlineAttributeReader
 
close() - Method in class cz.o2.proxima.direct.jdbc.JdbcOnlineAttributeWriter
 
close() - Method in interface cz.o2.proxima.direct.jdbc.SqlStatementFactory
 
close() - Method in class cz.o2.proxima.direct.server.transaction.TransactionContext
 
close() - Method in interface cz.o2.proxima.direct.server.transaction.TransactionContext.Transaction
 
close() - Method in class cz.o2.proxima.tools.groovy.Console
 
close() - Method in interface cz.o2.proxima.tools.groovy.StreamProvider
Close and release all resources.
close() - Method in class cz.o2.proxima.tools.io.ConsoleRandomReader
 
Closures - Class in cz.o2.proxima.tools.groovy.util
Utilities related to creating Closures from Java.
coder() - Static method in class cz.o2.proxima.beam.util.state.StateValue
 
coder(Coder<T>) - Static method in class cz.o2.proxima.beam.util.state.StateOrInput
 
collect() - Method in interface cz.o2.proxima.tools.groovy.Stream
Collect stream as list.
collect(T) - Method in interface cz.o2.proxima.core.transform.ElementWiseTransformation.Collector
Collect transformed value.
combine(Closure<K>, Closure<V>, V, Closure<V>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Apply combine transform to stream.
combine(Closure<K>, T, Closure<T>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Apply combine transform to stream.
combine(String, Closure<K>, Closure<V>, V, Closure<V>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Apply combine transform to stream.
combine(String, Closure<K>, T, Closure<T>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Apply combine transform to stream.
commit(boolean, Throwable) - Method in interface cz.o2.proxima.direct.core.CommitCallback
Commit the ingest process.
commit(boolean, Throwable) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogObserver.OffsetCommitter
Confirm processing of element.
commit(boolean, Throwable) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogObserver.OnNextContext
 
commit(CommitCallback) - Method in interface cz.o2.proxima.direct.server.transaction.TransactionContext.Transaction
 
commit(Rpc.TransactionCommitRequest, StreamObserver<Rpc.TransactionCommitResponse>) - Method in class cz.o2.proxima.direct.server.IngestService
 
commit(String, Collection<StreamElement>) - Method in interface cz.o2.proxima.direct.core.transaction.ClientTransactionManager
Commit the transaction with given output KeyAttributes being written.
commit(String, Collection<StreamElement>) - Method in class cz.o2.proxima.direct.core.transaction.TransactionResourceManager
 
Commit - Class in cz.o2.proxima.core.transaction
A commit request sent in case there are multiple output attributes written in a transaction.
Commit() - Constructor for class cz.o2.proxima.core.transaction.Commit
 
COMMIT - cz.o2.proxima.core.transaction.Request.Flags
 
COMMIT_ATTRIBUTE - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
COMMIT_LOG - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
COMMIT_LOG_APPEND - Static variable in class cz.o2.proxima.direct.server.metrics.Metrics
 
COMMIT_UPDATE_DISCARDED - Static variable in class cz.o2.proxima.direct.server.metrics.Metrics
 
Commit.TransactionUpdate - Class in cz.o2.proxima.core.transaction
An update to transactional attribute of a transaction.
CommitCallback - Interface in cz.o2.proxima.direct.core
Callback for write and commit log operations.
CommitLogObserver - Interface in cz.o2.proxima.direct.core.commitlog
Base interface for bulk and online observers.
CommitLogObserver.OffsetCommitter - Interface in cz.o2.proxima.direct.core.commitlog
Committer for manipulation with offset during consumption.
CommitLogObserver.OnIdleContext - Interface in cz.o2.proxima.direct.core.commitlog
CommitLogObserver.OnNextContext - Interface in cz.o2.proxima.direct.core.commitlog
CommitLogObserver.OnRepartitionContext - Interface in cz.o2.proxima.direct.core.commitlog
CommitLogObservers - Class in cz.o2.proxima.direct.core.commitlog
 
CommitLogObservers.ForwardingObserver - Class in cz.o2.proxima.direct.core.commitlog
A @{link LogObserver} that delegates calls to underlying delegate.
CommitLogObservers.TerminationStrategy - Enum in cz.o2.proxima.direct.core.commitlog
A strategy to use when maximal error count is reached.
CommitLogRead - Class in cz.o2.proxima.beam.core.direct.io
A PTransform that reads from a CommitLogReader using splittable DoFn.
CommitLogReader - Interface in cz.o2.proxima.direct.core.commitlog
Read access to commit log.
CommitLogReader.Factory<T extends CommitLogReader> - Interface in cz.o2.proxima.direct.core.commitlog
Serializable factory for CommitLogReader.
CommitLogReaders - Class in cz.o2.proxima.direct.core.commitlog
Utility class that constructs various versions of CommitLogReaders.
CommitLogReaders.LimitedCommitLogReader - Class in cz.o2.proxima.direct.core.commitlog
 
CommitLogSourceFunction<OutputT> - Class in cz.o2.proxima.flink.core
 
CommitLogSourceFunction(RepositoryFactory, List<AttributeDescriptor<?>>, ResultExtractor<OutputT>) - Constructor for class cz.o2.proxima.flink.core.CommitLogSourceFunction
 
committed() - Method in class cz.o2.proxima.core.transaction.Response
Create response for committed transaction.
committed(Collection<StreamElement>) - Method in class cz.o2.proxima.core.transaction.State
Create new State that is marked as State.Flags.COMMITTED.
COMMITTED - cz.o2.proxima.core.transaction.Response.Flags
 
COMMITTED - cz.o2.proxima.core.transaction.State.Flags
 
committer() - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogObserver.OnNextContext
Retrieve committer for currently processed record.
commitWrite(List<StreamElement>, CommitCallback) - Method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.Transaction
 
compareTo(Partition) - Method in interface cz.o2.proxima.core.storage.Partition
 
compareTo(Path) - Method in class cz.o2.proxima.direct.io.blob.BlobPath
 
compareTo(Path) - Method in class cz.o2.proxima.direct.io.bulkfs.LocalPath
 
CompileMojo - Class in cz.o2.proxima.maven
A MOJO for compiling config file to java classes.
CompileMojo() - Constructor for class cz.o2.proxima.maven.CompileMojo
 
Compiler - Class in cz.o2.proxima.tools.groovy
A compiler of conf files to groovy object.
composite(ElementWiseProxyTransform...) - Static method in interface cz.o2.proxima.core.transform.ElementWiseProxyTransform
 
compressed(Config) - Static method in interface cz.o2.proxima.core.repository.RepositoryFactory
 
ConfigConstants - Class in cz.o2.proxima.core.repository
Constants related to config parsing.
ConfigRepository - Class in cz.o2.proxima.core.repository
Repository of all entities configured in the system.
ConfigRepository.Builder - Class in cz.o2.proxima.core.repository
Builder for the repository.
Configuration() - Constructor for class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchClients.Configuration
 
configure() - Method in class cz.o2.proxima.direct.core.time.WatermarkConfiguration
 
ConfigUtils - Class in cz.o2.proxima.core.repository.config
Various utilities related to Config.
confirm() - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogObserver.OffsetCommitter
Successfully confirm the processing.
confirm(ID, long) - Method in class cz.o2.proxima.direct.io.kafka.OffsetCommitter
Confirm that action associated with given offset has been performed.
ConnFactory - Interface in cz.o2.proxima.direct.io.http
A factory for connections based on input elements.
Console - Class in cz.o2.proxima.tools.groovy
This is the groovysh based console.
ConsoleRandomReader - Class in cz.o2.proxima.tools.io
A random access reader for console.
ConsoleRandomReader(EntityDescriptor, DirectDataOperator) - Constructor for class cz.o2.proxima.tools.io.ConsoleRandomReader
 
Constants - Class in cz.o2.proxima.direct.server
Various (mostly config related) constants.
Consumer<T> - Interface in cz.o2.proxima.core.functional
Serializable consumer.
ConsumerNameFactory<T> - Interface in cz.o2.proxima.core.repository
Consumer name generator.
consumerWatermarkLags() - Static method in class cz.o2.proxima.direct.server.metrics.Metrics
 
containsKey(Object) - Method in class cz.o2.proxima.core.scheme.AttributeValueAccessors.StructureValueImpl
 
containsValue(Object) - Method in class cz.o2.proxima.core.scheme.AttributeValueAccessors.StructureValueImpl
 
context - Variable in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubReader
 
context - Variable in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubWriter
 
Context - Class in cz.o2.proxima.direct.core
Context created in local instance that can be distributed over wire.
Context(UnaryFunction<AttributeFamilyDescriptor, DirectAttributeFamilyDescriptor>, Factory<ExecutorService>) - Constructor for class cz.o2.proxima.direct.core.Context
 
ContextLoaderFence(ClassLoader) - Constructor for class cz.o2.proxima.core.util.internal.ClassLoaders.ContextLoaderFence
 
ContextProvider - Interface in cz.o2.proxima.direct.core
Provider or Context.
Contextual(DirectDataOperator, String, DirectElementWiseTransform, boolean, StorageFilter) - Constructor for class cz.o2.proxima.direct.core.transform.TransformationObserver.Contextual
 
ContextualProxyTransform<OP extends DataOperator> - Interface in cz.o2.proxima.core.transform
A ProxyTransform having (operator specific) context.
ContextualTransformation<OP extends DataOperator> - Interface in cz.o2.proxima.core.transform
 
Converter<T> - Interface in cz.o2.proxima.direct.jdbc
 
convertProtoToSchema(Descriptors.Descriptor) - Static method in class cz.o2.proxima.scheme.proto.utils.ProtoUtils
Covert proto object to proxima schema.
CORES - Static variable in class cz.o2.proxima.direct.server.Constants
 
count() - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Count elements.
count(String) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Count elements.
countByKey(Closure<K>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Count elements of stream by key.
countByKey(String, Closure<K>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Count elements of stream by key.
CqlFactory - Interface in cz.o2.proxima.direct.io.cassandra
A factory CQL queries for data access.
CqlFactory.KvIterable<T> - Interface in cz.o2.proxima.direct.io.cassandra
Interface for iteration over returned results returning KeyValues.
create() - Method in interface cz.o2.proxima.core.time.WatermarkEstimatorFactory
 
create() - Method in interface cz.o2.proxima.core.time.WatermarkIdlePolicyFactory
 
create() - Method in interface cz.o2.proxima.core.transaction.TransactionTransformProvider
Create the Transformation to be used for processing of Commits.
create() - Method in class cz.o2.proxima.direct.core.time.BoundedOutOfOrdernessWatermarkEstimator.Factory
 
create() - Method in class cz.o2.proxima.direct.core.time.NotProgressingWatermarkIdlePolicy.Factory
 
create() - Method in class cz.o2.proxima.direct.core.time.ProcessingTimeShiftingWatermarkIdlePolicy.Factory
 
create() - Method in class cz.o2.proxima.direct.core.time.ProcessingTimeWatermarkEstimator.Factory
 
create() - Method in class cz.o2.proxima.direct.core.time.SkewedProcessingTimeIdlePolicy.Factory
 
create() - Method in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator.Factory
 
create() - Method in class cz.o2.proxima.direct.core.transaction.TransactionCommitTransformProvider
 
create() - Method in class cz.o2.proxima.direct.io.kafka.KafkaConsumerFactory
Create an unnamed consumer consuming all partitions.
create() - Method in class cz.o2.proxima.direct.server.transaction.TransactionContext
 
create(Repository) - Method in class cz.o2.proxima.beam.core.BeamDataOperatorFactory
 
create(Repository) - Method in interface cz.o2.proxima.core.generator.OperatorGeneratorFactory
 
create(Repository) - Method in interface cz.o2.proxima.core.repository.DataOperatorFactory
Create the DataOperator instance.
create(Repository) - Method in class cz.o2.proxima.direct.core.DirectDataOperatorFactory
 
create(Repository) - Method in class cz.o2.proxima.direct.generator.DirectOperatorGeneratorFactory
 
create(Position, Collection<Partition>) - Method in class cz.o2.proxima.direct.io.kafka.KafkaConsumerFactory
Create unnamed consumer consuming given partitions.
create(DirectDataOperator, Metrics) - Method in interface cz.o2.proxima.direct.transaction.manager.TransactionLogObserverFactory
A factory for CommitLogObserver responsible for transaction management.
create(DirectDataOperator, Metrics) - Method in class cz.o2.proxima.direct.transaction.manager.TransactionLogObserverFactory.Default
 
create(DirectDataOperator, Metrics) - Method in class cz.o2.proxima.direct.transaction.manager.TransactionLogObserverFactory.WithOnErrorHandler
 
create(ElasticsearchClients.Configuration) - Static method in class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchClients
 
create(Config, Repository) - Static method in class cz.o2.proxima.tools.groovy.Console
 
create(Config, Repository, String[]) - Static method in class cz.o2.proxima.tools.groovy.Console
 
create(String) - Method in class cz.o2.proxima.direct.io.kafka.KafkaConsumerFactory
Create kafka consumer based on given parameters.
create(String) - Method in class cz.o2.proxima.direct.server.transaction.TransactionContext
 
create(String, int) - Static method in class cz.o2.proxima.direct.client.IngestClient
Create IngestClient instance
create(String, int, Options) - Static method in class cz.o2.proxima.direct.client.IngestClient
Create IngestClient instance
create(String, Position, ConsumerRebalanceListener) - Method in class cz.o2.proxima.direct.io.kafka.KafkaConsumerFactory
Create named consumer consuming from given position.
create(String, Map<String, Object>, Duration, String, String) - Method in class cz.o2.proxima.direct.io.bulkfs.DefaultNamingConventionFactory
 
create(String, Map<String, Object>, Duration, String, String) - Method in interface cz.o2.proxima.direct.io.bulkfs.NamingConventionFactory
Create NamingConvention that is used with FileFormat.
createAccessor(BeamDataOperator, AttributeFamilyDescriptor) - Method in class cz.o2.proxima.beam.core.direct.io.DirectDataAccessorFactory
 
createAccessor(BeamDataOperator, AttributeFamilyDescriptor) - Method in class cz.o2.proxima.beam.io.pubsub.PubSubDataAccessorFactory
 
createAccessor(BeamDataOperator, AttributeFamilyDescriptor) - Method in class cz.o2.proxima.beam.storage.TestStreamStorage
 
createAccessor(DirectDataOperator, AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.core.DirectDataOperator.DelegateDataAccessorFactory
 
createAccessor(DirectDataOperator, AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.core.StdoutStorage
 
createAccessor(DirectDataOperator, AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.io.bigtable.BigTableStorage
 
createAccessor(DirectDataOperator, AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.io.cassandra.CassandraStorageDescriptor
 
createAccessor(DirectDataOperator, AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchStorage
 
createAccessor(DirectDataOperator, AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.io.gcloud.storage.GCloudStorageDescriptor
 
createAccessor(DirectDataOperator, AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.io.hadoop.HadoopStorage
 
createAccessor(DirectDataOperator, AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.io.hbase.HBaseStorageDescriptor
 
createAccessor(DirectDataOperator, AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.io.http.HttpStorage
 
createAccessor(DirectDataOperator, AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.io.kafka.KafkaStorage
 
createAccessor(DirectDataOperator, AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.io.pubsub.PubSubStorage
 
createAccessor(DirectDataOperator, AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.io.s3.S3StorageDescriptor
 
createAccessor(DirectDataOperator, AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.jdbc.JdbcStorageDescriptor
 
createAccessor(OP, AttributeFamilyDescriptor) - Method in interface cz.o2.proxima.core.storage.internal.AbstractDataAccessorFactory
Create the accessor for give AttributeFamilyDescriptor.
createBatch(Pipeline, long, long) - Method in class cz.o2.proxima.beam.core.BeamProxyTransform
 
createBatch(Pipeline, List<AttributeDescriptor<?>>, long, long) - Method in class cz.o2.proxima.beam.core.AttributeFamilyProxyDataAccessor
 
createBatch(Pipeline, List<AttributeDescriptor<?>>, long, long) - Method in interface cz.o2.proxima.beam.core.DataAccessor
Create PCollection for given attribute family's batch updates storage.
createBatch(Pipeline, List<AttributeDescriptor<?>>, long, long) - Method in class cz.o2.proxima.beam.core.direct.io.DirectDataAccessorWrapper
 
createBatch(Pipeline, List<AttributeDescriptor<?>>, long, long) - Method in class cz.o2.proxima.beam.io.pubsub.PubSubDataAccessor
 
createBuilder(ElasticsearchClients.Configuration) - Static method in class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchClients
 
createCollector(CompilationUnit, SourceUnit) - Method in class cz.o2.proxima.tools.groovy.ToolsClassLoader
 
createConsumerFactory() - Method in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
Create kafka consumer with specific rebalance listener.
createDeleteStatement(StreamElement) - Method in class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
Create statement to be prepared for given ingest when deleting attribute.
createDeleteStatement(StreamElement) - Method in class cz.o2.proxima.direct.io.cassandra.DefaultCqlFactory
 
createDeleteStatement(StreamElement) - Method in class cz.o2.proxima.direct.io.cassandra.TransformingCqlFactory
 
createDeleteWildcardStatement(StreamElement) - Method in class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
Create statement to delete wildcard attribute.
createDeleteWildcardStatement(StreamElement) - Method in class cz.o2.proxima.direct.io.cassandra.DefaultCqlFactory
 
createDeleteWildcardStatement(StreamElement) - Method in class cz.o2.proxima.direct.io.cassandra.TransformingCqlFactory
 
createExecutor(Config) - Method in class cz.o2.proxima.direct.server.IngestServer
 
createFetchTokenStatement() - Method in class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
Create statement to fetch token for primary key.
createFetchTokenStatement() - Method in class cz.o2.proxima.direct.io.cassandra.DefaultCqlFactory
 
createFetchTokenStatement() - Method in class cz.o2.proxima.direct.io.cassandra.TransformingCqlFactory
 
createFrom(AttributeValueAccessors.StructureValue) - Method in class cz.o2.proxima.scheme.proto.ProtoMessageValueAccessor
 
createFrom(List<V>) - Method in interface cz.o2.proxima.core.scheme.AttributeValueAccessors.ArrayValueAccessor
 
createFrom(OutputT) - Method in interface cz.o2.proxima.core.scheme.AttributeValueAccessor
Create value from input object.
createFrom(V) - Method in class cz.o2.proxima.core.scheme.AttributeValueAccessors.PrimitiveValueAccessorImpl
 
createGetStatement(String, AttributeDescriptor) - Method in class cz.o2.proxima.direct.io.cassandra.TransformingCqlFactory
 
createGetStatement(String, AttributeDescriptor<?>) - Method in class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
Create get statement for key-attribute pair.
createGetStatement(String, AttributeDescriptor<?>) - Method in class cz.o2.proxima.direct.io.cassandra.DefaultCqlFactory
 
createInsertStatement(StreamElement) - Method in class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
Create statement to be prepared for given ingest.
createInsertStatement(StreamElement) - Method in class cz.o2.proxima.direct.io.cassandra.DefaultCqlFactory
 
createInsertStatement(StreamElement) - Method in class cz.o2.proxima.direct.io.cassandra.TransformingCqlFactory
 
createJarFromDynamicClasses(Map<? extends Class<?>, byte[]>) - Static method in class cz.o2.proxima.beam.util.RunnerUtils
Generate jar from provided map of dynamic classes.
createListAllStatement(Session) - Method in class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
Create statement to list all attributes of this entity.
createListAllStatement(Session) - Method in class cz.o2.proxima.direct.io.cassandra.DefaultCqlFactory
 
createListAllStatement(Session) - Method in class cz.o2.proxima.direct.io.cassandra.TransformingCqlFactory
 
createListEntitiesStatement() - Method in class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
Create list statement for entity keys.
createListEntitiesStatement() - Method in class cz.o2.proxima.direct.io.cassandra.DefaultCqlFactory
 
createListEntitiesStatement() - Method in class cz.o2.proxima.direct.io.cassandra.TransformingCqlFactory
 
createListStatement(AttributeDescriptor) - Method in class cz.o2.proxima.direct.io.cassandra.TransformingCqlFactory
 
createListStatement(AttributeDescriptor<?>) - Method in class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
Create list statement for key-wildcardAttribute pair.
createListStatement(AttributeDescriptor<?>) - Method in class cz.o2.proxima.direct.io.cassandra.DefaultCqlFactory
 
createPath(BlobT) - Method in class cz.o2.proxima.direct.io.blob.BlobLogReader
 
createPath(GCloudBlobPath.GCloudBlob) - Method in class cz.o2.proxima.direct.io.gcloud.storage.GCloudLogReader
 
createPath(S3BlobPath.S3Blob) - Method in class cz.o2.proxima.direct.io.s3.S3LogReader
 
createReader(PipelineOptions, DirectBatchUnboundedSource.Checkpoint) - Method in class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource
 
createServer(int, boolean) - Method in class cz.o2.proxima.direct.server.IngestServer
 
createStream(String, Pipeline, Position, boolean, boolean, long) - Method in class cz.o2.proxima.beam.core.AttributeFamilyProxyDataAccessor
 
createStream(String, Pipeline, Position, boolean, boolean, long) - Method in class cz.o2.proxima.beam.core.BeamProxyTransform
 
createStream(String, Pipeline, Position, boolean, boolean, long) - Method in interface cz.o2.proxima.beam.core.DataAccessor
Create PCollection for given attribute family's commit log.
createStream(String, Pipeline, Position, boolean, boolean, long) - Method in class cz.o2.proxima.beam.core.direct.io.DirectDataAccessorWrapper
 
createStream(String, Pipeline, Position, boolean, boolean, long) - Method in class cz.o2.proxima.beam.io.pubsub.PubSubDataAccessor
 
createStreamFromUpdates(Pipeline, long, long, long) - Method in class cz.o2.proxima.beam.core.BeamProxyTransform
 
createStreamFromUpdates(Pipeline, List<AttributeDescriptor<?>>, long, long, long) - Method in class cz.o2.proxima.beam.core.AttributeFamilyProxyDataAccessor
 
createStreamFromUpdates(Pipeline, List<AttributeDescriptor<?>>, long, long, long) - Method in interface cz.o2.proxima.beam.core.DataAccessor
Create PCollection for given attribute family's batchUpdates.
createStreamFromUpdates(Pipeline, List<AttributeDescriptor<?>>, long, long, long) - Method in class cz.o2.proxima.beam.core.direct.io.DirectDataAccessorWrapper
 
createStreamFromUpdates(Pipeline, List<AttributeDescriptor<?>>, long, long, long) - Method in class cz.o2.proxima.beam.io.pubsub.PubSubDataAccessor
 
createTransactionSerializerSchemeProvider() - Method in class cz.o2.proxima.core.scheme.JavaSerializer
 
createTransactionSerializerSchemeProvider() - Method in interface cz.o2.proxima.core.scheme.ValueSerializerFactory
 
createTransactionSerializerSchemeProvider() - Method in class cz.o2.proxima.scheme.proto.ProtoSerializerFactory
 
createWrapperClass() - Method in class cz.o2.proxima.tools.groovy.Console
 
createWrapperInLoader(Configuration, Repository, ToolsClassLoader) - Static method in class cz.o2.proxima.tools.groovy.GroovyEnv
 
CURRENT - cz.o2.proxima.core.storage.commitlog.Position
Read from given offsets (current).
currentRestriction() - Method in class cz.o2.proxima.beam.core.direct.io.BatchRestrictionTracker
 
currentRestriction() - Method in class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker
 
currentTransaction() - Method in interface cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.TransactionAware
 
currentTransaction() - Method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.TransactionValidator
 
cz.o2.proxima.beam.core - package cz.o2.proxima.beam.core
 
cz.o2.proxima.beam.core.direct.io - package cz.o2.proxima.beam.core.direct.io
 
cz.o2.proxima.beam.core.io - package cz.o2.proxima.beam.core.io
 
cz.o2.proxima.beam.core.transforms - package cz.o2.proxima.beam.core.transforms
 
cz.o2.proxima.beam.io - package cz.o2.proxima.beam.io
 
cz.o2.proxima.beam.io.pubsub - package cz.o2.proxima.beam.io.pubsub
 
cz.o2.proxima.beam.storage - package cz.o2.proxima.beam.storage
 
cz.o2.proxima.beam.tools.groovy - package cz.o2.proxima.beam.tools.groovy
 
cz.o2.proxima.beam.util - package cz.o2.proxima.beam.util
 
cz.o2.proxima.beam.util.state - package cz.o2.proxima.beam.util.state
 
cz.o2.proxima.core.annotations - package cz.o2.proxima.core.annotations
 
cz.o2.proxima.core.functional - package cz.o2.proxima.core.functional
 
cz.o2.proxima.core.generator - package cz.o2.proxima.core.generator
 
cz.o2.proxima.core.metrics - package cz.o2.proxima.core.metrics
 
cz.o2.proxima.core.repository - package cz.o2.proxima.core.repository
 
cz.o2.proxima.core.repository.config - package cz.o2.proxima.core.repository.config
 
cz.o2.proxima.core.scheme - package cz.o2.proxima.core.scheme
 
cz.o2.proxima.core.storage - package cz.o2.proxima.core.storage
 
cz.o2.proxima.core.storage.commitlog - package cz.o2.proxima.core.storage.commitlog
 
cz.o2.proxima.core.storage.internal - package cz.o2.proxima.core.storage.internal
 
cz.o2.proxima.core.storage.watermark - package cz.o2.proxima.core.storage.watermark
 
cz.o2.proxima.core.time - package cz.o2.proxima.core.time
 
cz.o2.proxima.core.transaction - package cz.o2.proxima.core.transaction
 
cz.o2.proxima.core.transform - package cz.o2.proxima.core.transform
 
cz.o2.proxima.core.util - package cz.o2.proxima.core.util
 
cz.o2.proxima.core.util.internal - package cz.o2.proxima.core.util.internal
 
cz.o2.proxima.core.utils.zookeeper - package cz.o2.proxima.core.utils.zookeeper
 
cz.o2.proxima.direct.client - package cz.o2.proxima.direct.client
 
cz.o2.proxima.direct.core - package cz.o2.proxima.direct.core
 
cz.o2.proxima.direct.core.batch - package cz.o2.proxima.direct.core.batch
 
cz.o2.proxima.direct.core.commitlog - package cz.o2.proxima.direct.core.commitlog
 
cz.o2.proxima.direct.core.randomaccess - package cz.o2.proxima.direct.core.randomaccess
 
cz.o2.proxima.direct.core.time - package cz.o2.proxima.direct.core.time
 
cz.o2.proxima.direct.core.transaction - package cz.o2.proxima.direct.core.transaction
 
cz.o2.proxima.direct.core.transform - package cz.o2.proxima.direct.core.transform
 
cz.o2.proxima.direct.core.view - package cz.o2.proxima.direct.core.view
 
cz.o2.proxima.direct.generator - package cz.o2.proxima.direct.generator
 
cz.o2.proxima.direct.io.bigtable - package cz.o2.proxima.direct.io.bigtable
 
cz.o2.proxima.direct.io.blob - package cz.o2.proxima.direct.io.blob
 
cz.o2.proxima.direct.io.bulkfs - package cz.o2.proxima.direct.io.bulkfs
 
cz.o2.proxima.direct.io.bulkfs.parquet - package cz.o2.proxima.direct.io.bulkfs.parquet
 
cz.o2.proxima.direct.io.cassandra - package cz.o2.proxima.direct.io.cassandra
 
cz.o2.proxima.direct.io.elasticsearch - package cz.o2.proxima.direct.io.elasticsearch
 
cz.o2.proxima.direct.io.gcloud.storage - package cz.o2.proxima.direct.io.gcloud.storage
 
cz.o2.proxima.direct.io.hadoop - package cz.o2.proxima.direct.io.hadoop
 
cz.o2.proxima.direct.io.hbase - package cz.o2.proxima.direct.io.hbase
 
cz.o2.proxima.direct.io.hdfs - package cz.o2.proxima.direct.io.hdfs
 
cz.o2.proxima.direct.io.http - package cz.o2.proxima.direct.io.http
 
cz.o2.proxima.direct.io.http.opentsdb - package cz.o2.proxima.direct.io.http.opentsdb
 
cz.o2.proxima.direct.io.kafka - package cz.o2.proxima.direct.io.kafka
 
cz.o2.proxima.direct.io.kafka.serializer - package cz.o2.proxima.direct.io.kafka.serializer
 
cz.o2.proxima.direct.io.pubsub - package cz.o2.proxima.direct.io.pubsub
 
cz.o2.proxima.direct.io.s3 - package cz.o2.proxima.direct.io.s3
 
cz.o2.proxima.direct.jdbc - package cz.o2.proxima.direct.jdbc
 
cz.o2.proxima.direct.server - package cz.o2.proxima.direct.server
 
cz.o2.proxima.direct.server.metrics - package cz.o2.proxima.direct.server.metrics
 
cz.o2.proxima.direct.server.transaction - package cz.o2.proxima.direct.server.transaction
 
cz.o2.proxima.direct.transaction.manager - package cz.o2.proxima.direct.transaction.manager
 
cz.o2.proxima.flink.core - package cz.o2.proxima.flink.core
 
cz.o2.proxima.flink.core.batch - package cz.o2.proxima.flink.core.batch
 
cz.o2.proxima.flink.utils - package cz.o2.proxima.flink.utils
 
cz.o2.proxima.generator - package cz.o2.proxima.generator
 
cz.o2.proxima.generator.cli - package cz.o2.proxima.generator.cli
 
cz.o2.proxima.io.pubsub.util - package cz.o2.proxima.io.pubsub.util
 
cz.o2.proxima.maven - package cz.o2.proxima.maven
 
cz.o2.proxima.scheme.avro - package cz.o2.proxima.scheme.avro
 
cz.o2.proxima.scheme.confluent - package cz.o2.proxima.scheme.confluent
 
cz.o2.proxima.scheme.proto - package cz.o2.proxima.scheme.proto
 
cz.o2.proxima.scheme.proto.testing - package cz.o2.proxima.scheme.proto.testing
 
cz.o2.proxima.scheme.proto.utils - package cz.o2.proxima.scheme.proto.utils
 
cz.o2.proxima.tools.groovy - package cz.o2.proxima.tools.groovy
 
cz.o2.proxima.tools.groovy.util - package cz.o2.proxima.tools.groovy.util
 
cz.o2.proxima.tools.io - package cz.o2.proxima.tools.io
 

D

DataAccessor - Interface in cz.o2.proxima.beam.core
A data accessor for attribute families.
DataAccessor - Interface in cz.o2.proxima.direct.core
Interface providing various types of data access patterns to storage.
DataAccessorFactory - Interface in cz.o2.proxima.beam.core
 
DataAccessorFactory - Interface in cz.o2.proxima.direct.core
Factory for DataAccessors from given URI.
DataAccessorLoader<OP extends DataOperator,​A extends AbstractDataAccessor,​T extends AbstractDataAccessorFactory<OP,​A>> - Class in cz.o2.proxima.core.storage.internal
Loader for various implementations of AbstractDataAccessorFactory.
DataOperator - Interface in cz.o2.proxima.core.repository
Labeling interface for Repository implementations to be able to mark their respective operators.
DataOperatorAgnostic - Interface in cz.o2.proxima.core.transform
 
DataOperatorAware - Interface in cz.o2.proxima.core.transform
 
DataOperatorFactory<T extends DataOperator> - Interface in cz.o2.proxima.core.repository
Factory for DataOperator with data accessing capabilities provided by specific implementation.
DateToLongConverter - Class in cz.o2.proxima.direct.io.cassandra
Represent a Date with String representation of epoch millis.
DateToLongConverter() - Constructor for class cz.o2.proxima.direct.io.cassandra.DateToLongConverter
 
days(int) - Static method in class cz.o2.proxima.beam.core.transforms.CalendarWindows
Returns a WindowFn that windows elements into periods measured by days.
DeclaredThreadSafe - Annotation Type in cz.o2.proxima.core.annotations
An annotation that can be used on types that do not need explicit synchronization.
decode(InputStream) - Method in class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource.CheckpointCoder
 
decode(InputStream) - Method in class cz.o2.proxima.beam.core.io.AttributeDescriptorCoder
 
decode(InputStream) - Method in class cz.o2.proxima.beam.core.io.EntityDescriptorCoder
 
decode(InputStream) - Method in class cz.o2.proxima.beam.core.io.PairCoder
 
decode(InputStream) - Method in class cz.o2.proxima.beam.core.io.StreamElementCoder
 
decode(InputStream) - Method in class cz.o2.proxima.beam.tools.groovy.TupleCoder
 
decode(InputStream) - Method in class cz.o2.proxima.beam.util.state.StateOrInput.StateOrInputCoder
 
decode(InputStream) - Method in class cz.o2.proxima.beam.util.state.StateValue.StateValueCoder
 
decrement() - Method in class cz.o2.proxima.core.metrics.Metric
Decrement metric by one.
Default() - Constructor for class cz.o2.proxima.beam.tools.groovy.BeamStreamProvider.Default
 
Default() - Constructor for class cz.o2.proxima.direct.core.transaction.ServerTransactionManager.InitialSequenceIdPolicy.Default
 
Default() - Constructor for class cz.o2.proxima.direct.io.elasticsearch.DocumentFormatter.Default
 
Default() - Constructor for class cz.o2.proxima.direct.transaction.manager.TransactionLogObserverFactory.Default
 
DEFAULT_ALLOWED_TIMESTAMP_SKEW - Static variable in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator
 
DEFAULT_ESTIMATE_DURATION_MS - Static variable in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator
 
DEFAULT_MAX_OUT_OF_ORDERNESS_MS - Static variable in class cz.o2.proxima.direct.core.time.BoundedOutOfOrdernessWatermarkEstimator
 
DEFAULT_NUM_THREADS - Static variable in class cz.o2.proxima.direct.server.Constants
 
DEFAULT_PORT - Static variable in class cz.o2.proxima.direct.server.Constants
 
DEFAULT_SLEEP_TIME_CFG - Static variable in class cz.o2.proxima.core.storage.watermark.GlobalWatermarkThroughputLimiter
Configuration key for the amount of time to sleep when reader is too far ahead global watermark in milliseconds.
DEFAULT_STEP_MS - Static variable in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator
 
DEFAULT_TIMESTAMP_SKEW - Static variable in class cz.o2.proxima.direct.core.time.SkewedProcessingTimeIdlePolicy
 
defaultContext(Partition) - Static method in class cz.o2.proxima.direct.core.batch.BatchLogObservers
Create BatchLogObserver.OnNextContext which holds watermark back on Watermarks.MIN_WATERMARK until the end of data.
defaultConvention(Duration, String, String) - Static method in interface cz.o2.proxima.direct.io.bulkfs.NamingConvention
Return default NamingConvention that is used with BinaryBlobFormat FileFormat.
DefaultConverter() - Constructor for class cz.o2.proxima.direct.io.cassandra.StringConverter.DefaultConverter
 
DefaultCqlFactory - Class in cz.o2.proxima.direct.io.cassandra
A CqlFactory used by default.
DefaultCqlFactory() - Constructor for class cz.o2.proxima.direct.io.cassandra.DefaultCqlFactory
 
DefaultNamingConvention - Class in cz.o2.proxima.direct.io.bulkfs
 
DefaultNamingConvention(Duration, String, String, Factory<String>) - Constructor for class cz.o2.proxima.direct.io.bulkfs.DefaultNamingConvention
 
DefaultNamingConventionFactory - Class in cz.o2.proxima.direct.io.bulkfs
Factory creates default convention for naming files.
DefaultNamingConventionFactory() - Constructor for class cz.o2.proxima.direct.io.bulkfs.DefaultNamingConventionFactory
 
defaultTesting() - Static method in enum cz.o2.proxima.core.repository.Repository.Validate
A default flag that is used when constructing Repository using Repository.ofTest(Config, Validate...)
DelegateDataAccessorFactory(DataAccessorFactory) - Constructor for class cz.o2.proxima.direct.core.DirectDataOperator.DelegateDataAccessorFactory
 
delete() - Method in class cz.o2.proxima.direct.io.blob.BlobPath
 
delete() - Method in class cz.o2.proxima.direct.io.bulkfs.LocalPath
 
delete() - Method in interface cz.o2.proxima.direct.io.bulkfs.Path
Delete this Path.
delete() - Method in class cz.o2.proxima.direct.io.gcloud.storage.GCloudBlobPath
 
delete() - Method in class cz.o2.proxima.direct.io.s3.S3BlobPath
 
delete(long, String, long) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Regular
Create delete for non-wildcard attribute.
delete(long, String, String, long) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Wildcard
Create delete for wildcard attribute.
delete(EntityDescriptor, AttributeDescriptor<?>, long, String, String, long) - Static method in class cz.o2.proxima.core.storage.StreamElement
Delete given instance of attribute.
delete(EntityDescriptor, AttributeDescriptor<?>, String, String) - Method in class cz.o2.proxima.tools.groovy.Console
 
delete(EntityDescriptor, AttributeDescriptor<?>, String, String, long) - Method in class cz.o2.proxima.tools.groovy.Console
 
delete(EntityDescriptor, AttributeDescriptor<?>, String, String, String, long) - Static method in class cz.o2.proxima.core.storage.StreamElement
Delete given instance of attribute.
delete(String, long) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Regular
Create delete for non-wildcard attribute.
delete(String, String, long) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Regular
Create delete for non-wildcard attribute.
delete(String, String, long) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Wildcard
Create delete for wildcard attribute.
delete(String, String, String, long) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Wildcard
Create delete for wildcard attribute.
delete(String, String, String, String, long, Consumer<Rpc.Status>) - Method in class cz.o2.proxima.direct.client.IngestClient
Send delete request.
delete(String, String, String, String, Consumer<Rpc.Status>) - Method in class cz.o2.proxima.direct.client.IngestClient
Send delete request.
delete(String, String, String, Instant) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Wildcard
Create delete for wildcard attribute.
delete(String, String, String, Consumer<Rpc.Status>) - Method in class cz.o2.proxima.direct.client.IngestClient
Send delete request.
delete(String, String, Instant) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Regular
Create delete for non-wildcard attribute.
delete(String, String, Instant) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Wildcard
Create delete for wildcard attribute.
delete(String, Instant) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Regular
Create delete for non-wildcard attribute.
DELETE_REQUESTS - Static variable in class cz.o2.proxima.direct.server.metrics.Metrics
 
DELETE_WILDCARD_REQUESTS - Static variable in class cz.o2.proxima.direct.server.metrics.Metrics
 
deleteBlobIfExists(BlobT) - Method in class cz.o2.proxima.direct.io.blob.BulkBlobWriter
Delete specified blob.
deleteBlobIfExists(GCloudBlobPath.GCloudBlob) - Method in class cz.o2.proxima.direct.io.gcloud.storage.BulkGCloudStorageWriter
 
deleteBlobIfExists(S3BlobPath.S3Blob) - Method in class cz.o2.proxima.direct.io.s3.BulkS3Writer
 
deleteWildcard(long, String, long) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Wildcard
Delete wildcard attribute (all versions).
deleteWildcard(EntityDescriptor, AttributeDescriptor<?>, long, String, long) - Static method in class cz.o2.proxima.core.storage.StreamElement
Delete all versions of given wildcard attribute.
deleteWildcard(EntityDescriptor, AttributeDescriptor<?>, long, String, String, long) - Static method in class cz.o2.proxima.core.storage.StreamElement
Delete all versions of given wildcard attribute.
deleteWildcard(EntityDescriptor, AttributeDescriptor<?>, String, String, long) - Static method in class cz.o2.proxima.core.storage.StreamElement
Delete all versions of given wildcard attribute.
deleteWildcard(EntityDescriptor, AttributeDescriptor<?>, String, String, String, long) - Static method in class cz.o2.proxima.core.storage.StreamElement
Delete all versions of given wildcard attribute.
deleteWildcard(String, long) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Wildcard
Delete wildcard attribute (all versions).
deleteWildcard(String, String, long) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Wildcard
Delete wildcard attribute (all versions).
deleteWildcard(String, String, Instant) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Wildcard
Delete wildcard attribute (all versions).
deleteWildcard(String, Instant) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Wildcard
Delete wildcard attribute (all versions).
desc() - Method in interface cz.o2.proxima.tools.groovy.AttributeDescriptorProvider
 
descriptor(TypeDescriptor<K>, TypeDescriptor<V>) - Static method in class cz.o2.proxima.beam.core.io.PairCoder
 
deserialize(byte[]) - Method in interface cz.o2.proxima.core.scheme.ValueSerializer
Deserialize the bytes to materialized typed message.
deserialize(byte[]) - Method in class cz.o2.proxima.scheme.avro.AvroSerializer
 
deserialize(ByteBuffer, int, int) - Method in class cz.o2.proxima.scheme.avro.AvroSerializer
 
die(String) - Method in class cz.o2.proxima.direct.core.transform.TransformationObserver
 
DirectAttributeFamilyDescriptor - Class in cz.o2.proxima.direct.core
Attribute descriptor with associated accessors.
DirectAttributeFamilyProxyDescriptor - Class in cz.o2.proxima.direct.core
Attribute family proxy descriptor for direct operator.
DirectBatchUnboundedSource - Class in cz.o2.proxima.beam.core.direct.io
Source reading from BatchLogReader in unbounded manner.
DirectBatchUnboundedSource.Checkpoint - Class in cz.o2.proxima.beam.core.direct.io
 
DirectBatchUnboundedSource.CheckpointCoder - Class in cz.o2.proxima.beam.core.direct.io
Use gzip to compress the serialized checkpoint, as it might easily grow in size (batch partitions might contain many files).
DirectDataAccessorFactory - Class in cz.o2.proxima.beam.core.direct.io
DirectDataAccessorFactory() - Constructor for class cz.o2.proxima.beam.core.direct.io.DirectDataAccessorFactory
 
DirectDataAccessorWrapper - Class in cz.o2.proxima.beam.core.direct.io
Wrapper of direct data accessor to beam one.
DirectDataAccessorWrapper(Repository, DataAccessor, AttributeFamilyDescriptor, Context) - Constructor for class cz.o2.proxima.beam.core.direct.io.DirectDataAccessorWrapper
 
DirectDataOperator - Class in cz.o2.proxima.direct.core
DataOperator implementation for direct accesses.
DirectDataOperator.DelegateDataAccessorFactory - Class in cz.o2.proxima.direct.core
 
DirectDataOperatorFactory - Class in cz.o2.proxima.direct.core
Factory for DirectDataOperator.
DirectDataOperatorFactory() - Constructor for class cz.o2.proxima.direct.core.DirectDataOperatorFactory
 
DirectElementWiseTransform - Interface in cz.o2.proxima.direct.core.transform
An element-wise transformation runnable in the context of DirectDataOperator only.
DirectOperatorGeneratorFactory - Class in cz.o2.proxima.direct.generator
DirectOperatorGeneratorFactory() - Constructor for class cz.o2.proxima.direct.generator.DirectOperatorGeneratorFactory
 
DISABLED - cz.o2.proxima.core.repository.TransformationDescriptor.OutputTransactionMode
Write transactional attributes on output directly to target commit-log.
DISABLED - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
disableRateLimiting() - Method in interface cz.o2.proxima.direct.core.batch.ObserveHandle
Disable any rate limit for this handle.
distinct() - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Output distinct elements.
distinct(Closure<?>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Output distinct elements through given mapper.
distinct(String) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Output distinct elements.
distinct(String, Closure<?>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Output distinct elements through given mapper.
DocumentFormatter - Interface in cz.o2.proxima.direct.io.elasticsearch
 
DocumentFormatter.Default - Class in cz.o2.proxima.direct.io.elasticsearch
 
DOUBLE - cz.o2.proxima.core.scheme.AttributeValueType
 
doubles() - Static method in class cz.o2.proxima.core.scheme.SchemaDescriptors
DoubleSerializer - Class in cz.o2.proxima.core.scheme
 
DoubleSerializer() - Constructor for class cz.o2.proxima.core.scheme.DoubleSerializer
 
drop() - Method in class cz.o2.proxima.core.repository.ConfigRepository
 
drop() - Method in class cz.o2.proxima.core.repository.Repository
Drop the Repository and let it recreate from scratch using factory.
drop() - Static method in class cz.o2.proxima.core.repository.RepositoryFactory.VersionedCaching
 
droppingUntilCharacter(char, String) - Static method in interface cz.o2.proxima.core.transform.ElementWiseProxyTransform
 
dump() - Method in class cz.o2.proxima.core.storage.StreamElement
Dump in more verbose way into given stream.
duplicate(long) - Method in class cz.o2.proxima.core.transaction.Response
Create response for duplicate transaction open requests.
DUPLICATE - cz.o2.proxima.core.transaction.Response.Flags
 

E

ElasticsearchAccessor - Class in cz.o2.proxima.direct.io.elasticsearch
 
ElasticsearchAccessor(EntityDescriptor, URI, Map<String, Object>) - Constructor for class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchAccessor
 
ElasticsearchClients - Class in cz.o2.proxima.direct.io.elasticsearch
 
ElasticsearchClients.Configuration - Class in cz.o2.proxima.direct.io.elasticsearch
 
ElasticsearchStorage - Class in cz.o2.proxima.direct.io.elasticsearch
 
ElasticsearchStorage() - Constructor for class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchStorage
 
ElasticsearchWriter - Class in cz.o2.proxima.direct.io.elasticsearch
 
ElasticsearchWriter(ElasticsearchAccessor) - Constructor for class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchWriter
 
ElementSerializer<K,​V> - Interface in cz.o2.proxima.direct.io.kafka
A parser that transforms KV from Kafka (byte[], byte[]) into StreamElement.
ElementWiseProxyTransform - Interface in cz.o2.proxima.core.transform
 
ElementWiseProxyTransform.ProxySetupContext - Interface in cz.o2.proxima.core.transform
 
ElementWiseTransformation - Interface in cz.o2.proxima.core.transform
A stateless element-wise transformation applied on incoming data converting single StreamElement to another StreamElement(s).
ElementWiseTransformation.Collector<T> - Interface in cz.o2.proxima.core.transform
Collector for outputs.
empty() - Static method in class cz.o2.proxima.core.transaction.Response
Create empty Response.
empty() - Static method in class cz.o2.proxima.core.transaction.State
 
empty() - Static method in class cz.o2.proxima.direct.io.cassandra.Offsets
 
EMPTY_POLL_TIME - Static variable in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
Minimal time poll() has to return empty records, before first moving watermark to processing time.
ENABLED - cz.o2.proxima.core.repository.TransformationDescriptor.OutputTransactionMode
Write all transactional attributes on output using transactions.
encode(DirectBatchUnboundedSource.Checkpoint, OutputStream) - Method in class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource.CheckpointCoder
 
encode(StateOrInput<T>, OutputStream) - Method in class cz.o2.proxima.beam.util.state.StateOrInput.StateOrInputCoder
 
encode(StateValue, OutputStream) - Method in class cz.o2.proxima.beam.util.state.StateValue.StateValueCoder
 
encode(AttributeDescriptor<?>, OutputStream) - Method in class cz.o2.proxima.beam.core.io.AttributeDescriptorCoder
 
encode(EntityDescriptor, OutputStream) - Method in class cz.o2.proxima.beam.core.io.EntityDescriptorCoder
 
encode(StreamElement, OutputStream) - Method in class cz.o2.proxima.beam.core.io.StreamElementCoder
 
encode(Pair<K, V>, OutputStream) - Method in class cz.o2.proxima.beam.core.io.PairCoder
 
encode(Tuple<Object>, OutputStream) - Method in class cz.o2.proxima.beam.tools.groovy.TupleCoder
 
end() - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementMaterializer.ParquetColumnRecordConverter
 
ensureTransactionOpen(String, State) - Method in interface cz.o2.proxima.direct.core.transaction.ServerTransactionManager
Ensure that the given transaction ID is initialized.
ensureTransactionOpen(String, State) - Method in class cz.o2.proxima.direct.core.transaction.TransactionResourceManager
 
ENTITIES - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
entity - Variable in class cz.o2.proxima.core.repository.AttributeDescriptorBase
 
ENTITY - cz.o2.proxima.core.repository.TransactionMode
Transactional support within the same entity (i.e.
ENTITY - cz.o2.proxima.direct.core.randomaccess.RandomAccessReader.Listing
 
ENTITY - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
EntityAwareAttributeDescriptor<T> - Class in cz.o2.proxima.core.repository
EntityAwareAttributeDescriptor.Regular<T> - Class in cz.o2.proxima.core.repository
 
EntityAwareAttributeDescriptor.Wildcard<T> - Class in cz.o2.proxima.core.repository
 
EntityDescriptor - Interface in cz.o2.proxima.core.repository
An interface representing descriptor of entity.
EntityDescriptor.Builder - Class in cz.o2.proxima.core.repository
Builder of the descriptor.
EntityDescriptorCoder - Class in cz.o2.proxima.beam.core.io
 
EntityDescriptorImpl - Class in cz.o2.proxima.core.repository
Descriptor of entity.
entrySet() - Method in class cz.o2.proxima.core.scheme.AttributeValueAccessors.StructureValueImpl
 
ENUM - cz.o2.proxima.core.scheme.AttributeValueAccessor.Type
 
ENUM - cz.o2.proxima.core.scheme.AttributeValueType
 
enums(List<String>) - Static method in class cz.o2.proxima.core.scheme.SchemaDescriptors
EnumTypeDescriptor(List<String>) - Constructor for class cz.o2.proxima.core.scheme.SchemaDescriptors.EnumTypeDescriptor
 
equals(Object) - Method in class cz.o2.proxima.beam.core.direct.io.BatchRestrictionTracker.PartitionList
 
equals(Object) - Method in class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource.Checkpoint
 
equals(Object) - Method in class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource
 
equals(Object) - Method in class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker.OffsetRange
 
equals(Object) - Method in class cz.o2.proxima.beam.core.io.PairCoder
 
equals(Object) - Method in class cz.o2.proxima.beam.core.io.StreamElementCoder
 
equals(Object) - Method in class cz.o2.proxima.beam.tools.groovy.TupleCoder
 
equals(Object) - Method in class cz.o2.proxima.beam.util.state.StateOrInput.StateOrInputCoder
 
equals(Object) - Method in class cz.o2.proxima.core.repository.AttributeDescriptorBase
 
equals(Object) - Method in class cz.o2.proxima.core.repository.AttributeFamilyDescriptor
 
equals(Object) - Method in class cz.o2.proxima.core.repository.ConfigRepository
 
equals(Object) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor
 
equals(Object) - Method in class cz.o2.proxima.core.repository.EntityDescriptorImpl
 
equals(Object) - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.ArrayTypeDescriptor
 
equals(Object) - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.EnumTypeDescriptor
 
equals(Object) - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.PrimitiveTypeDescriptor
 
equals(Object) - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.StructureTypeDescriptor
 
equals(Object) - Method in class cz.o2.proxima.core.storage.AbstractStorage
 
equals(Object) - Method in class cz.o2.proxima.core.storage.StreamElement
 
equals(Object) - Method in class cz.o2.proxima.core.util.NamePattern
 
equals(Object) - Method in class cz.o2.proxima.core.util.Pair
 
equals(Object) - Method in class cz.o2.proxima.core.util.SerializableScopedValue
 
equals(Object) - Method in class cz.o2.proxima.direct.core.DirectAttributeFamilyDescriptor
 
equals(Object) - Method in class cz.o2.proxima.direct.core.randomaccess.KeyValue
 
equals(Object) - Method in class cz.o2.proxima.direct.io.blob.BlobPath
 
equals(Object) - Method in class cz.o2.proxima.direct.io.hadoop.HadoopDataAccessor
 
ESTIMATE_DURATION_MS - Static variable in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator
 
estimateWatermark() - Method in class cz.o2.proxima.core.time.AbstractWatermarkEstimator
Estimates current watermark.
estimateWatermark() - Method in class cz.o2.proxima.direct.core.time.BoundedOutOfOrdernessWatermarkEstimator
 
estimateWatermark() - Method in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator
 
Evolving - Annotation Type in cz.o2.proxima.core.annotations
This annotation indicates that the given class or
ExceptionUtils - Class in cz.o2.proxima.core.util
Utilities related to exception throwing and handling.
ExceptionUtils.ThrowingBiConsumer<A,​B> - Interface in cz.o2.proxima.core.util
BiConsumer throwing exceptions.
ExceptionUtils.ThrowingConsumer<T> - Interface in cz.o2.proxima.core.util
Consumer throwing exceptions.
ExceptionUtils.ThrowingFactory<T> - Interface in cz.o2.proxima.core.util
Factory throwing exception.
ExceptionUtils.ThrowingRunnable - Interface in cz.o2.proxima.core.util
Runnable throwing exception.
ExceptionUtils.ThrowingUnaryFunction<IN,​OUT> - Interface in cz.o2.proxima.core.util
Function throwing exception.
execute() - Method in class cz.o2.proxima.maven.CompileMojo
 
EXIT - cz.o2.proxima.direct.core.commitlog.CommitLogObservers.TerminationStrategy
Immediately call System.exit(int)
expand(Pipeline, PTransform<PBegin, PCollection<KV<String, StateValue>>>, Instant, UnaryFunction<Instant, Instant>, PTransform<PCollection<KV<String, StateValue>>, PDone>) - Static method in class cz.o2.proxima.beam.util.state.ExternalStateExpander
Expand the given @{link Pipeline} to support external state store and restore
expand(PBegin) - Method in class cz.o2.proxima.beam.core.direct.io.BatchLogRead
 
expand(PBegin) - Method in class cz.o2.proxima.beam.core.direct.io.CommitLogRead
 
expand(PCollection<StreamElement>) - Method in class cz.o2.proxima.beam.io.ProximaIO.Write
 
expand(PCollection<T>) - Method in class cz.o2.proxima.beam.core.transforms.AssignEventTime
 
Experimental - Annotation Type in cz.o2.proxima.core.annotations
This annotation is used on experimental features and implementations.
ExternalStateExpander - Class in cz.o2.proxima.beam.util.state
 
ExtractKeyToKv - Class in cz.o2.proxima.beam.core.transforms
Extract key from StreamElement into KV.
extractSuffix(String) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Wildcard
Parse given attribute name (prefix.suffix) to suffix only.

F

Factory<T> - Interface in cz.o2.proxima.core.functional
A factory function.
Factory() - Constructor for class cz.o2.proxima.direct.core.time.BoundedOutOfOrdernessWatermarkEstimator.Factory
 
Factory() - Constructor for class cz.o2.proxima.direct.core.time.NotProgressingWatermarkIdlePolicy.Factory
 
Factory() - Constructor for class cz.o2.proxima.direct.core.time.ProcessingTimeShiftingWatermarkIdlePolicy.Factory
 
Factory() - Constructor for class cz.o2.proxima.direct.core.time.ProcessingTimeWatermarkEstimator.Factory
 
Factory() - Constructor for class cz.o2.proxima.direct.core.time.SkewedProcessingTimeIdlePolicy.Factory
 
Factory() - Constructor for class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator.Factory
 
fail(Throwable) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogObserver.OffsetCommitter
Confirm failure of processing.
FAMILIES - cz.o2.proxima.core.repository.Repository.Validate
Validate that attributes have associated families.
fetch(Consumer<Pair<RandomAccessReader.GetRequest<?>, Optional<KeyValue<?>>>>) - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader.MultiFetch
Perform the multi fetch and pass results through the provided consumer
fetchOffset(RandomAccessReader.Listing, String) - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
Construct Offset from string (representing either key of the entity or attribute).
fetchOffset(RandomAccessReader.Listing, String) - Method in class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
fetchOffset(RandomAccessReader.Listing, String) - Method in class cz.o2.proxima.direct.io.hbase.RandomHBaseReader
 
fetchOffset(RandomAccessReader.Listing, String) - Method in class cz.o2.proxima.direct.jdbc.JdbcOnlineAttributeReader
 
fetchOffsets(Position, List<Partition>) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Fetch offsets at given position from given partitions.
fetchOffsets(Position, List<Partition>) - Method in class cz.o2.proxima.direct.io.kafka.KafkaLogReader
 
FIELD_TYPES - Static variable in class cz.o2.proxima.beam.core.io.SchemaStreamElementCoder
 
FileFormat - Interface in cz.o2.proxima.direct.io.bulkfs
A specific format of data stored in bulk storage.
FileFormatUtils - Class in cz.o2.proxima.direct.io.bulkfs
Utility class to be shared between various bulk storages.
fileSuffix() - Method in interface cz.o2.proxima.direct.io.bulkfs.FileFormat
Retrieve suffix of file names.
fileSuffix() - Method in class cz.o2.proxima.direct.io.bulkfs.JsonFormat
 
fileSuffix() - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.ParquetFileFormat
 
FileSystem - Interface in cz.o2.proxima.direct.io.bulkfs
A proxima's abstraction of bulk FS.
filter(Closure<Boolean>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Filter stream based on predicate
filter(Closure<Boolean>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
 
filter(String, Closure<Boolean>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Filter stream based on predicate
filter(String, Closure<Boolean>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
 
FILTER - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
filters - Variable in class cz.o2.proxima.core.storage.StorageFilter.CompoundFilter
 
finalizeCheckpoint() - Method in class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource.Checkpoint
 
findAttribute(String) - Method in interface cz.o2.proxima.core.repository.EntityDescriptor
Find attribute by name.
findAttribute(String, boolean) - Method in interface cz.o2.proxima.core.repository.EntityDescriptor
Find attribute by name.
findAttribute(String, boolean) - Method in class cz.o2.proxima.core.repository.EntityDescriptorImpl
Find attribute based by name.
findClass(String, Class<T>) - Static method in class cz.o2.proxima.core.util.Classpath
Find given class.
findClass(String, String) - Method in class cz.o2.proxima.core.util.internal.ClassLoaders.ChildFirstURLClassLoader
 
findEntity(String) - Method in class cz.o2.proxima.core.repository.ConfigRepository
 
findEntity(String) - Method in class cz.o2.proxima.core.repository.Repository
Find entity descriptor based on entity name.
findEntityDescriptor(String) - Method in class cz.o2.proxima.tools.groovy.Console
 
findFamilyByName(String) - Method in class cz.o2.proxima.core.repository.ConfigRepository
 
findFamilyByName(String) - Method in class cz.o2.proxima.core.repository.Repository
Retrieve attribute family by name.
findFamilyByName(String) - Method in class cz.o2.proxima.direct.core.DirectDataOperator
Retrieve family by given name.
findForUri(URI) - Method in class cz.o2.proxima.core.storage.internal.DataAccessorLoader
Find AbstractDataAccessorFactory that best handles given URI.
findResource(String) - Method in class cz.o2.proxima.core.util.internal.ClassLoaders.ChildLayerFirstClassLoader
 
findResource(String, String) - Method in class cz.o2.proxima.core.util.internal.ClassLoaders.ChildLayerFirstClassLoader
 
findResources(String) - Method in class cz.o2.proxima.core.util.internal.ClassLoaders.ChildLayerFirstClassLoader
 
finished() - Method in class cz.o2.proxima.direct.core.batch.TerminationContext
 
finished(String) - Method in interface cz.o2.proxima.core.storage.watermark.GlobalWatermarkTracker
Remove given process from the tracker.
finished(String) - Method in class cz.o2.proxima.core.utils.zookeeper.ZKGlobalWatermarkTracker
 
finished(String) - Method in class cz.o2.proxima.flink.utils.FlinkGlobalWatermarkTracker
 
FirstPartitionPartitioner - Class in cz.o2.proxima.core.storage.commitlog
Partitioner that always send the ingest into first partition.
FirstPartitionPartitioner() - Constructor for class cz.o2.proxima.core.storage.commitlog.FirstPartitionPartitioner
 
flatMap(Closure<Iterable<X>>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Remap the stream.
flatMap(Closure<Iterable<X>>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
 
flatMap(String, Closure<Iterable<X>>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Remap the stream.
flatMap(String, Closure<Iterable<X>>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
 
FlinkGlobalWatermarkTracker - Class in cz.o2.proxima.flink.utils
 
FlinkGlobalWatermarkTracker() - Constructor for class cz.o2.proxima.flink.utils.FlinkGlobalWatermarkTracker
 
FLOAT - cz.o2.proxima.core.scheme.AttributeValueType
 
floats() - Static method in class cz.o2.proxima.core.scheme.SchemaDescriptors
FloatSerializer - Class in cz.o2.proxima.core.scheme
FloatSerializer() - Constructor for class cz.o2.proxima.core.scheme.FloatSerializer
 
flush(AbstractBulkFileSystemAttributeWriter.Bulk) - Method in class cz.o2.proxima.direct.io.bulkfs.AbstractBulkFileSystemAttributeWriter
Flush given AbstractBulkFileSystemAttributeWriter.Bulk to final output.
flush(AbstractBulkFileSystemAttributeWriter.Bulk) - Method in class cz.o2.proxima.direct.io.hadoop.HadoopBulkAttributeWriter
 
forRequest(Request) - Static method in class cz.o2.proxima.core.transaction.Response
Create Response that is targetted to be response for given request.
forStreamElement() - Static method in class cz.o2.proxima.beam.core.transforms.AssignEventTime
 
forTimestampFn(SerializableFunction<T, Instant>) - Static method in class cz.o2.proxima.beam.core.transforms.AssignEventTime
 
ForwardingBatchLogObserver(BatchLogObserver) - Constructor for class cz.o2.proxima.direct.core.batch.BatchLogReaders.ForwardingBatchLogObserver
 
ForwardingObserver(CommitLogObserver) - Constructor for class cz.o2.proxima.direct.core.commitlog.CommitLogObservers.ForwardingObserver
 
from(UnaryFunction<String, String>, UnaryFunction<String, String>) - Static method in interface cz.o2.proxima.core.transform.ElementWiseProxyTransform
 
from(Repository) - Static method in interface cz.o2.proxima.tools.groovy.RepositoryProvider
 
from(Object) - Static method in interface cz.o2.proxima.core.storage.AccessType
Return AccessType based on configuration specification.
from(Object, BiFunction<Object, Object, T>) - Static method in class cz.o2.proxima.tools.groovy.util.Closures
Create Closure from provided java lambda.
from(Object, Factory<T>) - Static method in class cz.o2.proxima.tools.groovy.util.Closures
Create Closure from provided java lambda.
from(Object, UnaryFunction<Object, T>) - Static method in class cz.o2.proxima.tools.groovy.util.Closures
Create Closure from provided java lambda.
FROM - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
fromArray(Object, UnaryFunction<Object[], T>) - Static method in class cz.o2.proxima.tools.groovy.util.Closures
Create Closure from provided java lambda.
fromBytes(byte[]) - Method in interface cz.o2.proxima.direct.core.commitlog.OffsetExternalizer
Deserializes offset from bytes, default implementation uses native java serialization.
fromJson(String) - Method in interface cz.o2.proxima.direct.core.commitlog.OffsetExternalizer
Deserializes offset from JSON string.
fromJsonValue(String) - Method in interface cz.o2.proxima.core.scheme.ValueSerializer
Convert given JSON string to parsed object.
fromProxy(String) - Method in interface cz.o2.proxima.core.transform.ElementWiseProxyTransform
Apply transformation to attribute name from proxy naming.
fromProxy(String) - Method in class cz.o2.proxima.core.transform.IdentityTransformation
 
fromStreamElements() - Static method in class cz.o2.proxima.beam.core.transforms.ExtractKeyToKv
 
fromString(String) - Method in class cz.o2.proxima.direct.io.cassandra.DateToLongConverter
 
fromString(String) - Method in class cz.o2.proxima.direct.io.cassandra.StringConverter.DefaultConverter
 
fromString(String) - Method in interface cz.o2.proxima.direct.io.cassandra.StringConverter
Convert type from string.
fromTimestamp(long) - Static method in class cz.o2.proxima.beam.core.transforms.StreamElementFilter
Filter StreamElement older or equal than provided timestamp
fromTimestamp(Instant) - Static method in class cz.o2.proxima.beam.core.transforms.StreamElementFilter
Filter StreamElement older or equal than provided Instant

G

gauge(String, String) - Method in class cz.o2.proxima.core.metrics.MetricFactory
Construct the metric.
GaugeMetric - Class in cz.o2.proxima.core.metrics
A metric that holds value that is set to it.
GCloudBlobPath - Class in cz.o2.proxima.direct.io.gcloud.storage
A Path representation of a remote Blob.
GCloudBlobPath.GCloudBlob - Class in cz.o2.proxima.direct.io.gcloud.storage
 
GCloudFileSystem - Class in cz.o2.proxima.direct.io.gcloud.storage
FileSystem implementation for gs://.
GCloudLogReader - Class in cz.o2.proxima.direct.io.gcloud.storage
BatchLogReader for gcloud storage.
GCloudLogReader(GCloudStorageAccessor, Context) - Constructor for class cz.o2.proxima.direct.io.gcloud.storage.GCloudLogReader
 
GCloudStorageDescriptor - Class in cz.o2.proxima.direct.io.gcloud.storage
A DataAccessorFactory for gcloud storage.
GCloudStorageDescriptor() - Constructor for class cz.o2.proxima.direct.io.gcloud.storage.GCloudStorageDescriptor
 
generate() - Method in class cz.o2.proxima.generator.ModelGenerator
 
generate(Writer) - Method in class cz.o2.proxima.generator.ModelGenerator
 
get() - Method in interface cz.o2.proxima.core.util.ExceptionUtils.ThrowingFactory
 
get() - Method in interface cz.o2.proxima.direct.core.time.TimestampSupplier
 
get() - Static method in class cz.o2.proxima.tools.groovy.Console
This is supposed to be called only from the groovysh initialized in this main method.
get(C) - Method in class cz.o2.proxima.core.util.SerializableScopedValue
 
get(HikariDataSource, AttributeDescriptor<?>, Object) - Method in interface cz.o2.proxima.direct.jdbc.SqlStatementFactory
 
get(RandomAccessReader.GetRequest<T>) - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
get(RandomAccessReader.GetRequest<T>) - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader.MultiFetch
Add new RandomAccessReader.GetRequest to the multi fetch.
get(Rpc.GetRequest) - Method in class cz.o2.proxima.direct.client.IngestClient
Sends synchronously Rpc.GetRequest to retrieve data from the system.
get(Rpc.GetRequest, StreamObserver<Rpc.GetResponse>) - Method in class cz.o2.proxima.direct.server.RetrieveService
 
get(Object) - Method in class cz.o2.proxima.core.scheme.AttributeValueAccessors.StructureValueImpl
 
get(String) - Method in interface cz.o2.proxima.core.scheme.AttributeValueAccessors.StructureValue
Type hinted get for field
get(String) - Method in class cz.o2.proxima.core.scheme.AttributeValueAccessors.StructureValueImpl
 
get(String) - Method in class cz.o2.proxima.direct.server.transaction.TransactionContext
 
get(String[]) - Static method in class cz.o2.proxima.tools.groovy.Console
 
get(String, AttributeDescriptor<T>) - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
Retrieve data stored under given (key, attribute) pair (if any).
get(String, AttributeDescriptor<T>, long) - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
Retrieve data stored under given (key, attribute) pair (if any).
get(String, String) - Method in class cz.o2.proxima.tools.io.ConsoleRandomReader
 
get(String, String, AttributeDescriptor<T>) - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
Retrieve data stored under given (key, attribute) pair (if any).
get(String, String, AttributeDescriptor<T>, long) - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
Retrieve data stored under given (key, attribute) pair (if any).
get(String, String, AttributeDescriptor<T>, long) - Method in class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
get(String, String, AttributeDescriptor<T>, long) - Method in class cz.o2.proxima.direct.io.hbase.RandomHBaseReader
 
get(String, String, AttributeDescriptor<T>, long) - Method in class cz.o2.proxima.direct.jdbc.JdbcOnlineAttributeReader
 
get(String, String, String) - Method in class cz.o2.proxima.direct.client.IngestClient
Sends synchronously Rpc.GetRequest to retrieve data from system.
get(Optional<T>) - Static method in class cz.o2.proxima.core.util.Optionals
 
get(Optional<T>, String, Object...) - Static method in class cz.o2.proxima.core.util.Optionals
 
GET_REQUESTS - Static variable in class cz.o2.proxima.direct.server.metrics.Metrics
 
get1() - Method in class cz.o2.proxima.core.metrics.Stats
 
get1() - Method in interface cz.o2.proxima.core.metrics.StatsMBean
 
get10() - Method in class cz.o2.proxima.core.metrics.Stats
 
get10() - Method in interface cz.o2.proxima.core.metrics.StatsMBean
 
get30() - Method in class cz.o2.proxima.core.metrics.Stats
 
get30() - Method in interface cz.o2.proxima.core.metrics.StatsMBean
 
get50() - Method in class cz.o2.proxima.core.metrics.Stats
 
get50() - Method in interface cz.o2.proxima.core.metrics.StatsMBean
 
get70() - Method in class cz.o2.proxima.core.metrics.Stats
 
get70() - Method in interface cz.o2.proxima.core.metrics.StatsMBean
 
get90() - Method in class cz.o2.proxima.core.metrics.Stats
 
get90() - Method in interface cz.o2.proxima.core.metrics.StatsMBean
 
get99() - Method in class cz.o2.proxima.core.metrics.Stats
 
get99() - Method in interface cz.o2.proxima.core.metrics.StatsMBean
 
getAcceptableScheme() - Method in class cz.o2.proxima.core.scheme.BytesSerializer
 
getAcceptableScheme() - Method in class cz.o2.proxima.core.scheme.DoubleSerializer
 
getAcceptableScheme() - Method in class cz.o2.proxima.core.scheme.FloatSerializer
 
getAcceptableScheme() - Method in class cz.o2.proxima.core.scheme.IntSerializer
 
getAcceptableScheme() - Method in class cz.o2.proxima.core.scheme.JavaSerializer
 
getAcceptableScheme() - Method in class cz.o2.proxima.core.scheme.JsonSerializer
 
getAcceptableScheme() - Method in class cz.o2.proxima.core.scheme.LongSerializer
 
getAcceptableScheme() - Method in class cz.o2.proxima.core.scheme.StringUtf8Serializer
 
getAcceptableScheme() - Method in interface cz.o2.proxima.core.scheme.ValueSerializerFactory
Retrieve scheme that of URI that this parser accepts.
getAcceptableScheme() - Method in class cz.o2.proxima.scheme.avro.AvroSerializerFactory
 
getAcceptableScheme() - Method in class cz.o2.proxima.scheme.confluent.SchemaRegistrySerializerFactory
 
getAcceptableScheme() - Method in class cz.o2.proxima.scheme.proto.JsonProtoSerializerFactory
 
getAcceptableScheme() - Method in class cz.o2.proxima.scheme.proto.ProtoSerializerFactory
 
getAccessorFactory(URI) - Method in class cz.o2.proxima.direct.core.DirectDataOperator
Retrieve factory that first matches given uri.
getAccessorFor(AttributeFamilyDescriptor) - Method in class cz.o2.proxima.beam.core.BeamDataOperator
getAddedURLs() - Method in class cz.o2.proxima.tools.groovy.ToolsClassLoader
 
getAllAttributes() - Method in interface cz.o2.proxima.core.repository.EntityDescriptor
List all attribute descriptors of given entity.
getAllAttributes(boolean) - Method in interface cz.o2.proxima.core.repository.EntityDescriptor
Find all attributes of this entity.
getAllAttributes(boolean) - Method in class cz.o2.proxima.core.repository.EntityDescriptorImpl
List all attribute descriptors of given entity.
getAllEntities() - Method in class cz.o2.proxima.core.repository.ConfigRepository
 
getAllEntities() - Method in class cz.o2.proxima.core.repository.Repository
Retrieve stream of all entities.
getAllFamilies() - Method in class cz.o2.proxima.core.repository.Repository
List all unique attribute families.
getAllFamilies() - Method in class cz.o2.proxima.direct.core.DirectDataOperator
Retrieve all families with their direct representation.
getAllFamilies(boolean) - Method in class cz.o2.proxima.core.repository.ConfigRepository
 
getAllFamilies(boolean) - Method in class cz.o2.proxima.core.repository.Repository
List all unique attribute families, possibly including system attribute families.
getAllowedLateness() - Method in class cz.o2.proxima.direct.io.blob.BlobStorageAccessor
 
getAssigned() - Method in interface cz.o2.proxima.direct.core.view.CachedView
Retrieve currently assigned partitions.
getAssigned() - Method in class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
getAttribute(String) - Method in interface cz.o2.proxima.core.repository.EntityDescriptor
Get attribute by name.
getAttribute(String, boolean) - Method in interface cz.o2.proxima.core.repository.EntityDescriptor
Get attribute by name.
getAttributes() - Method in class cz.o2.proxima.core.repository.AttributeFamilyDescriptor
 
getAttributes() - Method in class cz.o2.proxima.core.repository.TransformationDescriptor
 
getAttributes() - Method in class cz.o2.proxima.direct.core.DirectAttributeFamilyDescriptor
 
getAttributeSuffix() - Method in class cz.o2.proxima.core.transaction.KeyAttribute
 
getBatchLogReader(AttributeDescriptor<?>...) - Method in class cz.o2.proxima.direct.core.DirectDataOperator
getBatchLogReader(Context) - Method in interface cz.o2.proxima.direct.core.DataAccessor
Retrieve batch log reader.
getBatchLogReader(Context) - Method in class cz.o2.proxima.direct.io.cassandra.CassandraDBAccessor
 
getBatchLogReader(Context) - Method in class cz.o2.proxima.direct.io.hadoop.HadoopDataAccessor
 
getBatchLogReader(Context) - Method in class cz.o2.proxima.direct.io.hbase.HBaseDataAccessor
 
getBatchLogReader(Context) - Method in class cz.o2.proxima.direct.jdbc.JdbcDataAccessor
 
getBatchLogReader(Collection<AttributeDescriptor<?>>) - Method in class cz.o2.proxima.direct.core.DirectDataOperator
Retrieve BatchLogReader for given AttributeDescriptors.
getBatchReader() - Method in class cz.o2.proxima.direct.core.DirectAttributeFamilyDescriptor
Retrieve batch reader of this family.
getBatchSnapshot(long, long, StreamProvider.TerminatePredicate, AttributeDescriptor<?>...) - Method in class cz.o2.proxima.beam.tools.groovy.BeamStreamProvider
 
getBatchSnapshot(long, long, StreamProvider.TerminatePredicate, AttributeDescriptor<?>...) - Method in interface cz.o2.proxima.tools.groovy.StreamProvider
Retrieve batch snapshot stream.
getBatchSnapshot(AttributeDescriptor<?>) - Method in class cz.o2.proxima.tools.groovy.Console
 
getBatchSnapshot(AttributeDescriptor<?>, long, long) - Method in class cz.o2.proxima.tools.groovy.Console
 
getBatchSnapshot(Pipeline, long, long, AttributeDescriptor<?>...) - Method in class cz.o2.proxima.beam.core.BeamDataOperator
Create PCollection from snapshot of given attributes.
getBatchSnapshot(Pipeline, AttributeDescriptor<?>...) - Method in class cz.o2.proxima.beam.core.BeamDataOperator
Create PCollection from snapshot of given attributes.
getBatchUpdates(long, long, AttributeDescriptorProvider<?>...) - Method in class cz.o2.proxima.tools.groovy.Console
 
getBatchUpdates(long, long, StreamProvider.TerminatePredicate, AttributeDescriptor<?>...) - Method in class cz.o2.proxima.beam.tools.groovy.BeamStreamProvider
 
getBatchUpdates(long, long, StreamProvider.TerminatePredicate, AttributeDescriptor<?>...) - Method in interface cz.o2.proxima.tools.groovy.StreamProvider
Retrieve batch updates stream.
getBatchUpdates(Pipeline, long, long, boolean, AttributeDescriptor<?>...) - Method in class cz.o2.proxima.beam.core.BeamDataOperator
Create PCollection from updates to given attributes with given time range.
getBatchUpdates(Pipeline, long, long, AttributeDescriptor<?>...) - Method in class cz.o2.proxima.beam.core.BeamDataOperator
Create PCollection from updates to given attributes with given time range.
getBatchUpdates(Pipeline, AttributeDescriptor<?>...) - Method in class cz.o2.proxima.beam.core.BeamDataOperator
Create PCollection from updates to given attributes.
getBlob() - Method in class cz.o2.proxima.direct.io.blob.BlobPath
 
getBlobName() - Method in class cz.o2.proxima.direct.io.blob.BlobPath
 
getCachedView() - Method in class cz.o2.proxima.direct.core.DirectAttributeFamilyDescriptor
Retrieve cached view.
getCachedView(AttributeDescriptor<?>...) - Method in class cz.o2.proxima.direct.core.DirectDataOperator
Retrieve CachedView for given AttributeDescriptors.
getCachedView(Context) - Method in interface cz.o2.proxima.direct.core.DataAccessor
Retrieve cached view of the data.
getCachedView(Context) - Method in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
 
getCachedView(Collection<AttributeDescriptor<?>>) - Method in class cz.o2.proxima.direct.core.DirectDataOperator
Retrieve CachedView for given AttributeDescriptors.
getCfg() - Method in class cz.o2.proxima.beam.core.direct.io.DirectDataAccessorWrapper
 
getCfg() - Method in class cz.o2.proxima.core.repository.AttributeFamilyDescriptor
 
getCfg() - Method in interface cz.o2.proxima.direct.core.transaction.ServerTransactionManager
Retrieve a configuration read from the Repository.
getCfg() - Method in interface cz.o2.proxima.direct.core.transaction.TransactionManager
 
getCfg() - Method in class cz.o2.proxima.direct.io.blob.BlobStorageAccessor
 
getCfg() - Method in class cz.o2.proxima.direct.io.hadoop.HadoopDataAccessor
 
getCfgFromArgs(String[]) - Static method in class cz.o2.proxima.direct.server.IngestServer
 
getCheckpointMarkCoder() - Method in class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource
 
getClassByteCode(String) - Method in class cz.o2.proxima.tools.groovy.ToolsClassLoader
 
getClassName(URI) - Method in class cz.o2.proxima.core.scheme.BytesSerializer
 
getClassName(URI) - Method in class cz.o2.proxima.core.scheme.DoubleSerializer
 
getClassName(URI) - Method in class cz.o2.proxima.core.scheme.FloatSerializer
 
getClassName(URI) - Method in class cz.o2.proxima.core.scheme.IntSerializer
 
getClassName(URI) - Method in class cz.o2.proxima.core.scheme.JsonSerializer
 
getClassName(URI) - Method in class cz.o2.proxima.core.scheme.LongSerializer
 
getClassName(URI) - Method in class cz.o2.proxima.core.scheme.StringUtf8Serializer
 
getClassName(URI) - Method in interface cz.o2.proxima.core.scheme.ValueSerializerFactory
Retrieve class type for given scheme.
getClassName(URI) - Method in class cz.o2.proxima.scheme.confluent.SchemaRegistrySerializerFactory
 
getCleanupInterval() - Method in interface cz.o2.proxima.direct.core.transaction.TransactionManager.TransactionConfig
Get cleanup interval in milliseconds.
getClientTransactionManager() - Method in class cz.o2.proxima.direct.core.DirectDataOperator
 
getCoderArguments() - Method in class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource.CheckpointCoder
 
getCoderArguments() - Method in class cz.o2.proxima.beam.tools.groovy.TupleCoder
 
getColumns() - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementMaterializer.ParquetColumnGroup
 
getCommit() - Method in class cz.o2.proxima.direct.io.bulkfs.AbstractBulkFileSystemAttributeWriter.Bulk
 
getCommitDesc() - Method in interface cz.o2.proxima.direct.core.transaction.TransactionManager
 
getCommitLogReader() - Method in class cz.o2.proxima.direct.core.DirectAttributeFamilyDescriptor
Retrieve a commit log reader of this family.
getCommitLogReader(AttributeDescriptor<?>...) - Method in class cz.o2.proxima.direct.core.DirectDataOperator
getCommitLogReader(Context) - Method in interface cz.o2.proxima.direct.core.DataAccessor
Retrieve commit log reader (if applicable).
getCommitLogReader(Context) - Method in class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchAccessor
 
getCommitLogReader(Context) - Method in class cz.o2.proxima.direct.io.http.HttpAccessor
 
getCommitLogReader(Context) - Method in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
 
getCommitLogReader(Context) - Method in class cz.o2.proxima.direct.io.pubsub.PubSubAccessor
 
getCommitLogReader(Collection<AttributeDescriptor<?>>) - Method in class cz.o2.proxima.direct.core.DirectDataOperator
getCommitScheme() - Method in interface cz.o2.proxima.core.transaction.TransactionSerializerSchemeProvider
Retrieve scheme for serialization of Commit
getCommittedOffsets() - Method in interface cz.o2.proxima.direct.core.commitlog.ObserveHandle
Retrieve currently committed offsets.
getConfFactory() - Method in class cz.o2.proxima.direct.io.hbase.HBaseDataAccessor
Just for test purpose!
getConfiguration() - Method in class cz.o2.proxima.tools.groovy.ToolsClassLoader
 
getConnFactory(Map<String, Object>) - Method in class cz.o2.proxima.direct.io.http.HttpWriter
 
getConnFactory(Map<String, Object>) - Method in class cz.o2.proxima.direct.io.http.opentsdb.OpenTsdbWriter
 
getConsumedPartitions() - Method in interface cz.o2.proxima.core.storage.ThroughputLimiter.Context
Get collection of Partitions associated with reader reading with this limiter
getConsumerNameFactory() - Method in class cz.o2.proxima.core.repository.TransformationDescriptor
 
getContext() - Method in class cz.o2.proxima.direct.core.Context
 
getContext() - Method in interface cz.o2.proxima.direct.core.ContextProvider
 
getContext() - Method in class cz.o2.proxima.direct.core.DirectDataOperator
Retrieve Context that is used in all distributed operations.
getConverter(int) - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementMaterializer.ParquetColumnRecordConverter
 
getCreatePipelineFromOpts() - Method in class cz.o2.proxima.beam.tools.groovy.BeamStreamProvider
Convert PipelineOptions into Pipeline.
getCurrentOffsets() - Method in interface cz.o2.proxima.direct.core.commitlog.ObserveHandle
 
getCurrentOffsets() - Method in interface cz.o2.proxima.flink.core.batch.OffsetTrackingBatchLogReader.OffsetTrackingObserveHandle
Get consumed offset.
getCurrentRecord() - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementMaterializer
 
getCurrentRecord() - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementMaterializer.ParquetColumnRecordConverter
 
getCurrentState(String) - Method in interface cz.o2.proxima.direct.core.transaction.ServerTransactionManager
Retrieve current state of the transaction.
getCurrentState(String) - Method in class cz.o2.proxima.direct.core.transaction.TransactionResourceManager
Retrieve current state of the transaction.
getCurrentTime() - Method in interface cz.o2.proxima.core.functional.TimeProvider
 
getCurrentTime() - Method in interface cz.o2.proxima.core.time.WatermarkSupplier
 
getDayOfMonth() - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.MonthsWindows
 
getDayOfMonth() - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.YearsWindows
 
getDefault() - Method in interface cz.o2.proxima.core.scheme.ValueSerializer
Retrieve a default value for the type.
getDefault() - Static method in interface cz.o2.proxima.direct.io.cassandra.StringConverter
 
getDefaultEstimatorFactory() - Method in class cz.o2.proxima.direct.core.time.WatermarkConfiguration
Returns default estimator factory when none user's factory is provided.
getDefaultEstimatorFactory() - Method in class cz.o2.proxima.direct.io.kafka.KafkaWatermarkConfiguration
 
getDefaultEstimatorFactory() - Method in class cz.o2.proxima.direct.io.pubsub.PubSubWatermarkConfiguration
 
getDefaultIdlePolicyFactory() - Method in class cz.o2.proxima.direct.core.time.WatermarkConfiguration
Returns default idle policy factory when none user's factory is provided.
getDefaultIdlePolicyFactory() - Method in class cz.o2.proxima.direct.io.kafka.KafkaWatermarkConfiguration
 
getDefaultIdlePolicyFactory() - Method in class cz.o2.proxima.direct.io.pubsub.PubSubWatermarkConfiguration
 
getDefinedClasses() - Method in class cz.o2.proxima.tools.groovy.ToolsClassLoader
 
getDirect() - Method in class cz.o2.proxima.beam.core.BeamDataOperator
 
getDirect() - Method in class cz.o2.proxima.tools.groovy.Console
 
getDirect() - Method in interface cz.o2.proxima.tools.groovy.RepositoryProvider
 
getElementIndex() - Method in interface cz.o2.proxima.direct.core.batch.Offset
Index of the element within the partition.
getEncodedTypeDescriptor() - Method in class cz.o2.proxima.beam.core.io.AttributeDescriptorCoder
 
getEncodedTypeDescriptor() - Method in class cz.o2.proxima.beam.core.io.EntityDescriptorCoder
 
getEncodedTypeDescriptor() - Method in class cz.o2.proxima.beam.core.io.PairCoder
 
getEncodedTypeDescriptor() - Method in class cz.o2.proxima.beam.core.io.StreamElementCoder
 
getEntity() - Method in interface cz.o2.proxima.core.repository.AttributeDescriptor
Retrieve name of the associated entity.
getEntity() - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor
 
getEntity(String) - Method in class cz.o2.proxima.core.repository.Repository
Get entity descriptor based on entity name.
getEntityDescriptor() - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
Retrieve entity associated with this reader.
getEntityDescriptor() - Method in class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
getEntityDescriptor() - Method in class cz.o2.proxima.direct.io.blob.BulkBlobWriter
getEntityDescriptor() - Method in class cz.o2.proxima.direct.io.hbase.RandomHBaseReader
 
getExecutorFactory() - Method in class cz.o2.proxima.direct.core.Context
 
getExecutorService() - Method in class cz.o2.proxima.direct.core.Context
Get executor for asynchronous tasks.
getFamiliesForAttribute(AttributeDescriptor<?>) - Method in class cz.o2.proxima.core.repository.ConfigRepository
 
getFamiliesForAttribute(AttributeDescriptor<?>) - Method in class cz.o2.proxima.core.repository.Repository
Retrieve list of attribute families for attribute.
getFamiliesForAttribute(AttributeDescriptor<?>) - Method in class cz.o2.proxima.direct.core.DirectDataOperator
Resolve all direct attribute representations of given attribute.
getFamilyByName(String) - Method in class cz.o2.proxima.core.repository.Repository
Retrieve attribute family by name.
getFamilyByName(String) - Method in class cz.o2.proxima.direct.core.DirectDataOperator
Retrieve family by given name.
getFetchTokenStatement(String, Session) - Method in class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
 
getFetchTokenStatement(String, Session) - Method in interface cz.o2.proxima.direct.io.cassandra.CqlFactory
Retrieve a bound statement to fetch a token for given entity.
getField(String) - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.StructureTypeDescriptor
Get field descriptor for given field name.
getFields() - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.StructureTypeDescriptor
Get fields in structure type.
getFileFormat(String, Map<String, Object>) - Static method in class cz.o2.proxima.direct.io.bulkfs.FileFormatUtils
Get FileFormat from configuration.
getFileSystem() - Method in class cz.o2.proxima.direct.io.blob.BlobPath
 
getFileSystem() - Method in class cz.o2.proxima.direct.io.bulkfs.LocalPath
 
getFileSystem() - Method in interface cz.o2.proxima.direct.io.bulkfs.Path
Retrieve FileSystem of this Path.
getFirstPartition() - Method in class cz.o2.proxima.beam.core.direct.io.BatchRestrictionTracker.PartitionList
 
getFlushInterval() - Method in class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchAccessor
 
getGlobalTransactionWriter() - Method in class cz.o2.proxima.direct.core.DirectDataOperator
Retrieve a TransactionalOnlineAttributeWriter with GLOBAL transactions capable to fulfil any transactional requests.
getGlobalWatermark(String, long) - Method in interface cz.o2.proxima.core.storage.watermark.GlobalWatermarkTracker
Retrieve global watermark tracked by this tracker.
getGlobalWatermark(String, long) - Method in class cz.o2.proxima.core.utils.zookeeper.ZKGlobalWatermarkTracker
 
getGlobalWatermark(String, long) - Method in class cz.o2.proxima.flink.utils.FlinkGlobalWatermarkTracker
 
getGroup() - Method in interface cz.o2.proxima.core.metrics.ScalarMetricMBean
 
getId() - Method in interface cz.o2.proxima.core.storage.Partition
Retrieve id of the partition.
getId() - Method in class cz.o2.proxima.direct.core.batch.BoundedPartition
 
getIdleWatermark() - Method in interface cz.o2.proxima.core.time.WatermarkIdlePolicy
Returns watermark for idle source.
getIdleWatermark() - Method in class cz.o2.proxima.direct.core.time.NotProgressingWatermarkIdlePolicy
 
getIdleWatermark() - Method in class cz.o2.proxima.direct.core.time.ProcessingTimeShiftingWatermarkIdlePolicy
 
getIdleWatermark() - Method in class cz.o2.proxima.direct.core.time.SkewedProcessingTimeIdlePolicy
 
getImpulse(String, Closure<T>) - Method in class cz.o2.proxima.tools.groovy.Console
 
getInitialSeqIdPolicy() - Method in interface cz.o2.proxima.direct.core.transaction.ServerTransactionManager.ServerTransactionConfig
Get initial sequential ID policy.
getKeyFromResult(ResultSet) - Method in interface cz.o2.proxima.direct.jdbc.Converter
 
getKeyFromResult(ResultSet) - Method in class cz.o2.proxima.direct.jdbc.RowAsJsonConverter
 
getListAllStatement(String, Offsets.Raw, int, Session) - Method in interface cz.o2.proxima.direct.io.cassandra.CqlFactory
Retrieve wrapped statement to execute to list all attributes of given key.
getListAllStatement(String, Offsets.Raw, int, Session) - Method in class cz.o2.proxima.direct.io.cassandra.DefaultCqlFactory
 
getListAllStatement(String, Offsets.Raw, int, Session) - Method in class cz.o2.proxima.direct.io.cassandra.TransformingCqlFactory
 
getListEntitiesStatement(Offsets.Token, int, Session) - Method in class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
 
getListEntitiesStatement(Offsets.Token, int, Session) - Method in interface cz.o2.proxima.direct.io.cassandra.CqlFactory
Get statement for listing entities.
getListStatement(String, AttributeDescriptor<?>, Offsets.Raw, int, Session) - Method in interface cz.o2.proxima.direct.io.cassandra.CqlFactory
Retrieve a CQL query to execute in order to list wildcard attributes.
getListStatement(String, AttributeDescriptor<?>, Offsets.Raw, int, Session) - Method in class cz.o2.proxima.direct.io.cassandra.DefaultCqlFactory
 
getListStatement(String, AttributeDescriptor, Offsets.Raw, int, Session) - Method in class cz.o2.proxima.direct.io.cassandra.TransformingCqlFactory
 
getLogString(T) - Method in interface cz.o2.proxima.core.scheme.ValueSerializer
Create a (preferably single line) String representation of the value suitable for logging.
getMaxTimestamp() - Method in interface cz.o2.proxima.core.storage.Partition
 
getMinTimestamp() - Method in class cz.o2.proxima.beam.core.direct.io.BatchRestrictionTracker.PartitionList
 
getMinTimestamp() - Method in interface cz.o2.proxima.core.storage.Partition
 
getMinWatermark() - Method in interface cz.o2.proxima.core.storage.ThroughputLimiter.Context
Retrieve current reader's watermark (minimum of all partitions).
getMonthOfYear() - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.YearsWindows
 
getName() - Method in interface cz.o2.proxima.core.metrics.ScalarMetricMBean
 
getName() - Method in interface cz.o2.proxima.core.repository.AttributeDescriptor
Retrieve name of the attribute.
getName() - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor
 
getName() - Method in interface cz.o2.proxima.core.repository.EntityDescriptor
Name of the entity.
getName() - Method in interface cz.o2.proxima.core.storage.watermark.GlobalWatermarkTracker
Retrieve name of this tracker.
getName() - Method in class cz.o2.proxima.core.utils.zookeeper.ZKGlobalWatermarkTracker
 
getName() - Method in interface cz.o2.proxima.direct.io.blob.BlobBase
Retrieve remote name (key) of blob.
getName() - Method in class cz.o2.proxima.direct.io.gcloud.storage.GCloudBlobPath.GCloudBlob
 
getName() - Method in class cz.o2.proxima.flink.utils.FlinkGlobalWatermarkTracker
 
getNamingConvention() - Method in class cz.o2.proxima.direct.io.blob.BlobStorageAccessor
 
getNamingConvention(String, Map<String, Object>, long, FileFormat) - Static method in class cz.o2.proxima.direct.io.bulkfs.FileFormatUtils
Retrieve NamingConvention from configuration.
getNumber() - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.DaysWindows
 
getNumber() - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.MonthsWindows
 
getNumber() - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.YearsWindows
 
getOffset() - Method in interface cz.o2.proxima.direct.core.LogObserver.OnNextContext
Retrieve offset of the current element.
getOffsetExternalizer() - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Provides offset externalizer for serializing log specific offsets to external formats (bytes, JSON).
getOffsetExternalizer() - Method in class cz.o2.proxima.direct.io.kafka.KafkaLogReader
 
getOperatorClassName() - Method in interface cz.o2.proxima.core.generator.OperatorGenerator
Retrieve name of class that represents the DataOperator implementation.
getOperatorName() - Method in class cz.o2.proxima.beam.core.BeamDataOperatorFactory
 
getOperatorName() - Method in interface cz.o2.proxima.core.repository.DataOperatorFactory
Retrieve symbolic name of the operator.
getOperatorName() - Method in class cz.o2.proxima.direct.core.DirectDataOperatorFactory
 
getOrCreateOperator(Class<T>, Consumer<T>...) - Method in class cz.o2.proxima.core.repository.Repository
Retrieve instance of data operator or create new instance with given settings.
getOutputCoder() - Method in class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource
 
getParsed() - Method in class cz.o2.proxima.core.storage.StreamElement
Retrieve parsed value.
getParsedRequired() - Method in class cz.o2.proxima.direct.core.randomaccess.KeyValue
Equivalent of getParsed().get() throwing explaining exceptions.
getPartition() - Method in class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker.OffsetRange
 
getPartition() - Method in interface cz.o2.proxima.direct.core.batch.Offset
Partition the offset belongs to.
getPartition() - Method in interface cz.o2.proxima.direct.core.commitlog.Offset
Which partition is this offset for
getPartition() - Method in interface cz.o2.proxima.direct.core.LogObserver.OnNextContext
Retrieve partition for currently processed record.
getPartitionId(StreamElement) - Method in class cz.o2.proxima.core.storage.commitlog.FirstPartitionPartitioner
 
getPartitionId(StreamElement) - Method in class cz.o2.proxima.core.storage.commitlog.KeyAttributePartitioner
 
getPartitionId(StreamElement) - Method in class cz.o2.proxima.core.storage.commitlog.KeyPartitioner
 
getPartitionId(StreamElement) - Method in interface cz.o2.proxima.core.storage.commitlog.Partitioner
Retrieve partition ID for the specified ingest.
getPartitionId(StreamElement) - Method in class cz.o2.proxima.core.transaction.TransactionPartitioner
 
getPartitionIdForResponse() - Method in class cz.o2.proxima.core.transaction.Response
 
getPartitionMaxNumBlobs() - Method in class cz.o2.proxima.direct.io.blob.BlobStorageAccessor
 
getPartitionMaxTimeSpanMs() - Method in class cz.o2.proxima.direct.io.blob.BlobStorageAccessor
 
getPartitionMinSize() - Method in class cz.o2.proxima.direct.io.blob.BlobStorageAccessor
 
getPartitions() - Method in interface cz.o2.proxima.direct.core.batch.BatchLogReader
Retrieve list of partitions of this batch observer.
getPartitions() - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Retrieve list of partitions of this commit log.
getPartitions() - Method in interface cz.o2.proxima.direct.core.view.CachedView
Retrieve all partitions of the underlying commit log.
getPartitions() - Method in class cz.o2.proxima.direct.io.http.WebsocketReader
 
getPartitions() - Method in class cz.o2.proxima.direct.io.kafka.KafkaLogReader
 
getPartitions() - Method in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubReader
 
getPartitions(long) - Method in interface cz.o2.proxima.direct.core.batch.BatchLogReader
Retrieve list of partitions covering data at least from given starting stamp.
getPartitions(long, long) - Method in interface cz.o2.proxima.direct.core.batch.BatchLogReader
Retrieve list of partitions covering data from the given range.
getPartitions(long, long) - Method in class cz.o2.proxima.direct.io.blob.BlobLogReader
 
getPartitions(long, long) - Method in class cz.o2.proxima.direct.io.hadoop.HadoopBatchLogReader
 
getPartitions(long, long) - Method in class cz.o2.proxima.direct.jdbc.JdbcBatchLogReader
 
getPartitions(long, long) - Method in class cz.o2.proxima.flink.core.batch.OffsetTrackingBatchLogReader
 
getPath() - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.ProximaParquetReader
 
getPath() - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.ProximaParquetWriter
 
getPath() - Method in interface cz.o2.proxima.direct.io.bulkfs.Reader
Get Path associated with the Reader.
getPath() - Method in interface cz.o2.proxima.direct.io.bulkfs.Writer
Get Path associated with the Writer.
getPathNormalized(URI) - Static method in class cz.o2.proxima.core.storage.UriUtil
Get normalized path from URI, which: is not null doesn't start or end with slash
getPauseTime(ThroughputLimiter.Context) - Method in interface cz.o2.proxima.core.storage.ThroughputLimiter
Retrieve the amount of time the source should pause processing for.
getPauseTime(ThroughputLimiter.Context) - Method in class cz.o2.proxima.core.storage.ThroughputLimiter.NoOpThroughputLimiter
 
getPauseTime(ThroughputLimiter.Context) - Method in class cz.o2.proxima.core.storage.watermark.GlobalWatermarkThroughputLimiter
 
getPeriodicImpulse(String, Closure<T>, long) - Method in class cz.o2.proxima.tools.groovy.Console
 
getPipelineOptions() - Method in class cz.o2.proxima.beam.core.direct.io.BatchLogRead.BatchLogReadOptionsFactory
 
getPipelineOptionsFactory() - Method in class cz.o2.proxima.beam.tools.groovy.BeamStreamProvider.Default
 
getPipelineOptionsFactory() - Method in class cz.o2.proxima.beam.tools.groovy.BeamStreamProvider
Create factory to be used for pipeline creation.
getPreparedGetStatement(Session, String, AttributeDescriptor<?>) - Method in class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
Retrieve cached prepared statement for getting data from cassandra for given attribute.
getPreparedListAllStatement(Session) - Method in class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
 
getPreparedListStatement(Session, AttributeDescriptor<?>) - Method in class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
Retrieve cached prepared statement for listing data by attribute prefix (for wildcard attributes).
getPreparedStatement(Session, StreamElement) - Method in class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
Retrieve cached prepared statement for writing given data.
getPrimaryFamilyFor(AttributeDescriptor<?>) - Method in class cz.o2.proxima.core.repository.ConfigRepository
 
getProgress() - Method in class cz.o2.proxima.beam.core.direct.io.BatchRestrictionTracker
 
getProgress() - Method in class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker
 
getProxyAttribute() - Method in interface cz.o2.proxima.core.transform.ElementWiseProxyTransform.ProxySetupContext
Retrieve attribute that is the proxied attribute.
getRandomAccess(AttributeDescriptor<?>...) - Method in class cz.o2.proxima.direct.core.DirectDataOperator
getRandomAccess(Collection<AttributeDescriptor<?>>) - Method in class cz.o2.proxima.direct.core.DirectDataOperator
getRandomAccessReader() - Method in class cz.o2.proxima.direct.core.DirectAttributeFamilyDescriptor
Retrieve a random access reader.
getRandomAccessReader(Context) - Method in interface cz.o2.proxima.direct.core.DataAccessor
Retrieve random access reader.
getRandomAccessReader(Context) - Method in class cz.o2.proxima.direct.io.cassandra.CassandraDBAccessor
 
getRandomAccessReader(Context) - Method in class cz.o2.proxima.direct.io.hbase.HBaseDataAccessor
 
getRandomAccessReader(Context) - Method in class cz.o2.proxima.direct.jdbc.JdbcDataAccessor
 
getRandomAccessReader(String) - Method in class cz.o2.proxima.tools.groovy.Console
 
getRaw() - Method in class cz.o2.proxima.direct.io.cassandra.Offsets.Raw
 
getRawManager() - Method in class cz.o2.proxima.direct.transaction.manager.TransactionLogObserver
 
getReadStatement(String, String, AttributeDescriptor<?>, Session) - Method in interface cz.o2.proxima.direct.io.cassandra.CqlFactory
Retrieve a CQL query to execute in order to read data.
getReadStatement(String, String, AttributeDescriptor<?>, Session) - Method in class cz.o2.proxima.direct.io.cassandra.DefaultCqlFactory
 
getReadStatement(String, String, AttributeDescriptor, Session) - Method in class cz.o2.proxima.direct.io.cassandra.TransformingCqlFactory
 
getRepo() - Method in class cz.o2.proxima.beam.tools.groovy.StreamConfig
 
getRepo() - Method in interface cz.o2.proxima.tools.groovy.RepositoryProvider
 
getRepository() - Method in class cz.o2.proxima.beam.core.BeamDataOperator
 
getRepository() - Method in interface cz.o2.proxima.core.repository.DataOperator
Retrieve repository associated with the operator.
getRepository() - Method in class cz.o2.proxima.direct.core.DirectDataOperator
 
GetRequest() - Constructor for class cz.o2.proxima.direct.core.randomaccess.RandomAccessReader.GetRequest
 
getRequestDesc() - Method in interface cz.o2.proxima.direct.core.transaction.TransactionManager
 
getRequestScheme() - Method in interface cz.o2.proxima.core.transaction.TransactionSerializerSchemeProvider
Retrieve scheme for serialization of Request
getResponseDesc() - Method in interface cz.o2.proxima.direct.core.transaction.TransactionManager
 
getResponseScheme() - Method in interface cz.o2.proxima.core.transaction.TransactionSerializerSchemeProvider
Retrieve scheme for serialization of Request
getRestHighLevelClient() - Method in class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchAccessor
 
getRollPeriod() - Method in class cz.o2.proxima.direct.io.blob.BlobStorageAccessor
 
getRootConverter() - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementMaterializer
 
getRunningHandle() - Method in interface cz.o2.proxima.direct.core.view.CachedView
Retrieve a running handle (if present).
getRunningHandle() - Method in class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
getSchemaTypeDescriptor() - Method in interface cz.o2.proxima.core.repository.AttributeDescriptor
Return SchemaDescriptors.SchemaTypeDescriptor for given attribute value.
getSchemaTypeDescriptor() - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor
 
getSchemeUri() - Method in interface cz.o2.proxima.core.repository.AttributeDescriptor
Retrieve URI of the scheme of this attribute.
getSchemeUri() - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor
 
getSerializer() - Method in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
getServerTerminationTimeoutSeconds() - Method in interface cz.o2.proxima.direct.core.transaction.ServerTransactionManager.ServerTransactionConfig
 
getServerTransactionManager() - Method in class cz.o2.proxima.direct.core.DirectDataOperator
 
getServices() - Method in class cz.o2.proxima.direct.server.IngestServer
 
getSize() - Method in interface cz.o2.proxima.direct.io.blob.BlobBase
Get size of blob in bytes.
getSize() - Method in class cz.o2.proxima.direct.io.gcloud.storage.GCloudBlobPath.GCloudBlob
 
getSize() - Method in class cz.o2.proxima.direct.io.s3.S3BlobPath.S3Blob
 
getSource() - Method in class cz.o2.proxima.core.repository.AttributeFamilyDescriptor
Retrieve optional name of source attribute family, if this is replica.
getSource() - Method in class cz.o2.proxima.direct.core.DirectAttributeFamilyDescriptor
Retrieve optional name of source attribute family, if this is replica.
getSource(Configuration, Repository) - Static method in class cz.o2.proxima.tools.groovy.GroovyEnv
 
getSource(Configuration, Repository, String) - Static method in class cz.o2.proxima.tools.groovy.GroovyEnv
 
getStartBatchReadDelayMs() - Method in interface cz.o2.proxima.beam.core.direct.io.BatchLogRead.BatchLogReadPipelineOptions
 
getStartDate() - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.DaysWindows
 
getStartDate() - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.MonthsWindows
 
getStartDate() - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.YearsWindows
 
getStateDesc() - Method in interface cz.o2.proxima.direct.core.transaction.TransactionManager
 
getStateScheme() - Method in interface cz.o2.proxima.core.transaction.TransactionSerializerSchemeProvider
Retrieve scheme for serialization of Request
getStream(AttributeDescriptor<T>, Position, boolean) - Method in class cz.o2.proxima.tools.groovy.Console
 
getStream(AttributeDescriptor<T>, Position, boolean, boolean) - Method in class cz.o2.proxima.tools.groovy.Console
 
getStream(Position, boolean, boolean, StreamProvider.TerminatePredicate, AttributeDescriptor<?>...) - Method in class cz.o2.proxima.beam.tools.groovy.BeamStreamProvider
 
getStream(Position, boolean, boolean, StreamProvider.TerminatePredicate, AttributeDescriptor<?>...) - Method in interface cz.o2.proxima.tools.groovy.StreamProvider
Create stream from commit log(s).
getStream(String, Pipeline, Position, boolean, boolean, AttributeDescriptor<?>...) - Method in class cz.o2.proxima.beam.core.BeamDataOperator
Create PCollection in given Pipeline from commit log for given attributes.
getStream(Pipeline, Position, boolean, boolean, AttributeDescriptor<?>...) - Method in class cz.o2.proxima.beam.core.BeamDataOperator
Create PCollection in given Pipeline from commit log for given attributes.
getTargetAttribute() - Method in interface cz.o2.proxima.core.transform.ElementWiseProxyTransform.ProxySetupContext
Retrieve attribute that is target of this transform (attribute to read from, or to write to).
getTargetFileSystem() - Method in class cz.o2.proxima.direct.io.blob.BlobStorageAccessor
 
getTimestampFromResult(ResultSet) - Method in interface cz.o2.proxima.direct.jdbc.Converter
 
getTimeZone() - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.DaysWindows
 
getTimeZone() - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.MonthsWindows
 
getTimeZone() - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.YearsWindows
 
getTmpDir() - Method in class cz.o2.proxima.direct.io.blob.BlobStorageAccessor
 
getToken() - Method in class cz.o2.proxima.direct.io.cassandra.Offsets.Token
 
getTransaction() - Method in interface cz.o2.proxima.direct.core.transaction.TransactionManager
 
getTransactionalManagerFamilies() - Method in interface cz.o2.proxima.core.repository.AttributeDescriptor
Retrieve transactional manager families for this attribute.
getTransactionalManagerFamilies() - Method in class cz.o2.proxima.core.repository.AttributeDescriptorImpl
 
getTransactionalManagerFamilies() - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor
 
getTransactionId() - Method in interface cz.o2.proxima.direct.server.transaction.TransactionContext.Transaction
 
getTransactionMode() - Method in interface cz.o2.proxima.core.repository.AttributeDescriptor
Retrieve type of transactional support of this attribute.
getTransactionMode() - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor
 
getTransactionMonitoringPolicy() - Method in interface cz.o2.proxima.direct.core.transaction.ServerTransactionManager.ServerTransactionConfig
 
getTransactionTimeoutMs() - Method in interface cz.o2.proxima.direct.core.transaction.TransactionManager.TransactionConfig
 
getTransformations() - Method in class cz.o2.proxima.core.repository.ConfigRepository
 
getTransformations() - Method in class cz.o2.proxima.core.repository.Repository
Retrieve all transformers.
getTruncatedPartitionId(Partitioner, StreamElement, int) - Static method in class cz.o2.proxima.core.storage.commitlog.Partitioners
 
getType() - Method in interface cz.o2.proxima.core.scheme.AttributeValueAccessor
Get accessor type
getType() - Method in interface cz.o2.proxima.core.scheme.AttributeValueAccessors.ArrayValueAccessor
 
getType() - Method in interface cz.o2.proxima.core.scheme.AttributeValueAccessors.PrimitiveValueAccessor
 
getType() - Method in interface cz.o2.proxima.core.scheme.AttributeValueAccessors.StructureValueAccessor
 
getType() - Method in interface cz.o2.proxima.core.scheme.SchemaDescriptors.SchemaTypeDescriptor
Return attribute value type
getType() - Method in interface cz.o2.proxima.direct.core.AttributeWriterBase
Retrieve type of the writer.
getType() - Method in interface cz.o2.proxima.direct.core.BulkAttributeWriter
 
getType() - Method in interface cz.o2.proxima.direct.core.OnlineAttributeWriter
 
getType() - Method in class cz.o2.proxima.direct.core.transaction.TransactionalCachedView
 
getUnderlyingReader() - Method in interface cz.o2.proxima.direct.core.view.CachedView
Retrieve underlying CommitLogReader.
getUnderlyingReader() - Method in class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
getUnderlyingWriter() - Method in interface cz.o2.proxima.direct.core.view.CachedView
Retrieve underlying OnlineAttributeWriter.
getUnderlyingWriter() - Method in class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
getUnionStream(Position, boolean, boolean, AttributeDescriptorProvider<?>...) - Method in class cz.o2.proxima.tools.groovy.Console
 
getUri() - Method in class cz.o2.proxima.beam.core.AttributeFamilyProxyDataAccessor
 
getUri() - Method in interface cz.o2.proxima.core.storage.internal.AbstractDataAccessor
Retrieve URI associated with this AbstractDataAccessor.
getUri() - Method in interface cz.o2.proxima.direct.core.AttributeWriterBase
Retrieve URI of this writer.
getUri() - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Retrieve URI representing this resource.
getUri() - Method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter
 
getUri() - Method in class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
getUri() - Method in class cz.o2.proxima.direct.io.blob.BulkBlobWriter
 
getUri() - Method in interface cz.o2.proxima.direct.io.bulkfs.FileSystem
Ger URI representation of this FileSystem
getUri() - Method in class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchWriter
 
getUri() - Method in class cz.o2.proxima.direct.io.gcloud.storage.GCloudFileSystem
 
getUri() - Method in class cz.o2.proxima.direct.io.hadoop.HadoopBulkAttributeWriter
 
getUri() - Method in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubWriter
 
getUri() - Method in class cz.o2.proxima.direct.io.s3.S3FileSystem
 
getUriRemapped() - Method in class cz.o2.proxima.direct.io.hadoop.HadoopDataAccessor
 
getUuid() - Method in class cz.o2.proxima.core.storage.StreamElement
 
getValue() - Method in class cz.o2.proxima.core.metrics.AbsoluteMetric
 
getValue() - Method in class cz.o2.proxima.core.metrics.ApproxPercentileMetric
 
getValue() - Method in interface cz.o2.proxima.core.metrics.ApproxPercentileMetricMXBean
 
getValue() - Method in class cz.o2.proxima.core.metrics.GaugeMetric
 
getValue() - Method in class cz.o2.proxima.core.metrics.Metric
Retrieve current value of the metric.
getValue() - Method in interface cz.o2.proxima.core.metrics.ScalarMetricMBean
 
getValue() - Method in class cz.o2.proxima.core.metrics.TimeAveragingMetric
 
getValueAccessor() - Method in interface cz.o2.proxima.core.scheme.AttributeValueAccessors.ArrayValueAccessor
 
getValueAccessor() - Method in interface cz.o2.proxima.core.scheme.ValueSerializer
Provide AttributeValueAccessor for give attribute value.
getValueBytes(ResultSet, AttributeDescriptor<String>) - Method in class cz.o2.proxima.direct.jdbc.RowAsJsonConverter
 
getValueBytes(ResultSet, AttributeDescriptor<T>) - Method in interface cz.o2.proxima.direct.jdbc.Converter
 
getValues() - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.EnumTypeDescriptor
 
getValueSchemaDescriptor() - Method in interface cz.o2.proxima.core.scheme.ValueSerializer
Provide SchemaDescriptors.SchemaTypeDescriptor for given attribute value.
getValueSerializer() - Method in interface cz.o2.proxima.core.repository.AttributeDescriptor
Retrieve serializer for value type.
getValueSerializer() - Method in class cz.o2.proxima.core.repository.AttributeDescriptorBase
 
getValueSerializer() - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor
 
getValueSerializer(URI) - Method in class cz.o2.proxima.core.scheme.BytesSerializer
 
getValueSerializer(URI) - Method in class cz.o2.proxima.core.scheme.DoubleSerializer
 
getValueSerializer(URI) - Method in class cz.o2.proxima.core.scheme.FloatSerializer
 
getValueSerializer(URI) - Method in class cz.o2.proxima.core.scheme.IntSerializer
 
getValueSerializer(URI) - Method in class cz.o2.proxima.core.scheme.JavaSerializer
 
getValueSerializer(URI) - Method in class cz.o2.proxima.core.scheme.JsonSerializer
 
getValueSerializer(URI) - Method in class cz.o2.proxima.core.scheme.LongSerializer
 
getValueSerializer(URI) - Method in class cz.o2.proxima.core.scheme.StringUtf8Serializer
 
getValueSerializer(URI) - Method in interface cz.o2.proxima.core.scheme.ValueSerializerFactory
Get ValueSerializer for given scheme.
getValueSerializer(URI) - Method in class cz.o2.proxima.scheme.avro.AvroSerializerFactory
 
getValueSerializer(URI) - Method in class cz.o2.proxima.scheme.confluent.SchemaRegistrySerializerFactory
 
getValueSerializer(URI) - Method in class cz.o2.proxima.scheme.proto.JsonProtoSerializerFactory
 
getValueSerializer(URI) - Method in class cz.o2.proxima.scheme.proto.ProtoSerializerFactory
 
getValueSerializerFactory(String) - Method in class cz.o2.proxima.core.repository.ConfigRepository
 
getValueSerializerFactory(String) - Method in class cz.o2.proxima.core.repository.Repository
Retrieve value serializer for given scheme.
getValueType() - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.ArrayTypeDescriptor
Get AttributeValueType for array value.
getWatermark() - Method in interface cz.o2.proxima.core.storage.watermark.GlobalWatermarkTracker
 
getWatermark() - Method in class cz.o2.proxima.core.time.AbstractWatermarkEstimator
Returns monotonically increasing estimated watermark.
getWatermark() - Method in interface cz.o2.proxima.core.time.PartitionedWatermarkEstimator
Returns estimated watermark across all partitions.
getWatermark() - Method in interface cz.o2.proxima.core.time.WatermarkEstimator
Returns estimated watermark.
getWatermark() - Method in interface cz.o2.proxima.core.time.WatermarkSupplier
Retrieve watermark.
getWatermark() - Method in interface cz.o2.proxima.direct.core.batch.BatchLogObserver.OnNextContext
Retrieve current watermark of the observe process
getWatermark() - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogObserver.OnIdleContext
 
getWatermark() - Method in interface cz.o2.proxima.direct.core.commitlog.Offset
Retrieve watermark associated with this offset.
getWatermark() - Method in class cz.o2.proxima.direct.core.time.MinimalPartitionWatermarkEstimator
 
getWatermark() - Method in class cz.o2.proxima.direct.core.time.ProcessingTimeWatermarkEstimator
 
getWatermark(int) - Method in class cz.o2.proxima.direct.core.time.MinimalPartitionWatermarkEstimator
 
getWriter() - Method in class cz.o2.proxima.direct.core.DirectAttributeFamilyDescriptor
Retrieve writer for this family.
getWriter(AttributeDescriptor<?>) - Method in class cz.o2.proxima.direct.core.DirectDataOperator
Retrieve writer for given AttributeDescriptor.
getWriter(Context) - Method in interface cz.o2.proxima.direct.core.DataAccessor
Retrieve writer (if applicable).
getWriter(Context) - Method in class cz.o2.proxima.direct.io.cassandra.CassandraDBAccessor
 
getWriter(Context) - Method in class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchAccessor
 
getWriter(Context) - Method in class cz.o2.proxima.direct.io.hadoop.HadoopDataAccessor
 
getWriter(Context) - Method in class cz.o2.proxima.direct.io.hbase.HBaseDataAccessor
 
getWriter(Context) - Method in class cz.o2.proxima.direct.io.http.HttpAccessor
 
getWriter(Context) - Method in class cz.o2.proxima.direct.io.http.HttpWriter
 
getWriter(Context) - Method in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
 
getWriter(Context) - Method in class cz.o2.proxima.direct.io.pubsub.PubSubAccessor
 
getWriter(Context) - Method in class cz.o2.proxima.direct.jdbc.JdbcDataAccessor
 
getWriteStatement(StreamElement, Session) - Method in interface cz.o2.proxima.direct.io.cassandra.CqlFactory
Retrieve a CQL query to execute in order to ingest the request.
getWriteStatement(StreamElement, Session) - Method in class cz.o2.proxima.direct.io.cassandra.DefaultCqlFactory
 
getWriteStatement(StreamElement, Session) - Method in class cz.o2.proxima.direct.io.cassandra.TransformingCqlFactory
 
global(DirectDataOperator) - Static method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter
 
GLOBAL_WATERMARK_UPDATE_MS_CFG - Static variable in class cz.o2.proxima.core.storage.watermark.GlobalWatermarkThroughputLimiter
Configuration key for number of milliseconds to pass between two updates of global watermark.
GlobalWatermarkThroughputLimiter - Class in cz.o2.proxima.core.storage.watermark
A ThroughputLimiter that synchronizes progress of global watermark among distributed consumers.
GlobalWatermarkThroughputLimiter() - Constructor for class cz.o2.proxima.core.storage.watermark.GlobalWatermarkThroughputLimiter
 
GlobalWatermarkTracker - Interface in cz.o2.proxima.core.storage.watermark
A tracker of global watermark progress among multiple (distributed) processes.
GroovyEnv - Class in cz.o2.proxima.tools.groovy
Dynamic groovy descriptor of entity.
GROUP - Static variable in class cz.o2.proxima.direct.server.metrics.Metrics
 
groupReduce(Closure<K>, Closure<Iterable<V>>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Reduce stream with reduce function taking list of values.
groupReduce(String, Closure<K>, Closure<Iterable<V>>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Reduce stream with reduce function taking list of values.
GStringSerializer - Class in cz.o2.proxima.beam.tools.groovy
 
GStringSerializer() - Constructor for class cz.o2.proxima.beam.tools.groovy.GStringSerializer
 
gunzip(byte[], Charset) - Static method in class cz.o2.proxima.core.util.StringCompressions
Un-gzip byte buffer to string.
gzip(String, Charset) - Static method in class cz.o2.proxima.core.util.StringCompressions
Gzip compress a given string.

H

HADOOP_ALLOWED_LATENESS - Static variable in class cz.o2.proxima.direct.io.hadoop.HadoopDataAccessor
 
HADOOP_BATCH_PROCESS_SIZE_MIN - Static variable in class cz.o2.proxima.direct.io.hadoop.HadoopDataAccessor
 
HADOOP_ROLL_INTERVAL - Static variable in class cz.o2.proxima.direct.io.hadoop.HadoopDataAccessor
 
HadoopBatchLogReader - Class in cz.o2.proxima.direct.io.hadoop
Reader of data stored in SequenceFiles in HDFS.
HadoopBatchLogReader(HadoopDataAccessor, Context) - Constructor for class cz.o2.proxima.direct.io.hadoop.HadoopBatchLogReader
 
HadoopBulkAttributeWriter - Class in cz.o2.proxima.direct.io.hadoop
Bulk attribute writer to Hadoop FileSystem.
HadoopBulkAttributeWriter(HadoopDataAccessor, Context) - Constructor for class cz.o2.proxima.direct.io.hadoop.HadoopBulkAttributeWriter
 
HadoopDataAccessor - Class in cz.o2.proxima.direct.io.hadoop
DataAccessor for Hadoop Distributed FileSystem.
HadoopDataAccessor(AttributeFamilyDescriptor) - Constructor for class cz.o2.proxima.direct.io.hadoop.HadoopDataAccessor
 
HadoopPartition - Class in cz.o2.proxima.direct.io.hadoop
Partition of files in HDFS.
HadoopPartition(int) - Constructor for class cz.o2.proxima.direct.io.hadoop.HadoopPartition
 
HadoopStorage - Class in cz.o2.proxima.direct.io.hadoop
Writer to HDFS.
HadoopStorage() - Constructor for class cz.o2.proxima.direct.io.hadoop.HadoopStorage
 
handleErrorCaught(Throwable, Runnable) - Method in class cz.o2.proxima.direct.core.batch.TerminationContext
 
handleLateData(StreamElement, long, CommitCallback) - Method in class cz.o2.proxima.direct.io.bulkfs.AbstractBulkFileSystemAttributeWriter
Handle data after watermark.
hasDirect() - Method in class cz.o2.proxima.beam.core.BeamDataOperator
 
hasExternalizableOffsets() - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Signals the user that offsets used by this reader can be externalized and reused later.
hasExternalizableOffsets() - Method in class cz.o2.proxima.direct.io.kafka.KafkaLogReader
 
hasExternalizableOffsets() - Method in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubReader
 
hasField(String) - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.StructureTypeDescriptor
Return true if field with given name exists in structure.
hashCode() - Method in class cz.o2.proxima.beam.core.direct.io.BatchRestrictionTracker.PartitionList
 
hashCode() - Method in class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource.Checkpoint
 
hashCode() - Method in class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource
 
hashCode() - Method in class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker.OffsetRange
 
hashCode() - Method in class cz.o2.proxima.beam.core.io.PairCoder
 
hashCode() - Method in class cz.o2.proxima.beam.core.io.StreamElementCoder
 
hashCode() - Method in class cz.o2.proxima.beam.tools.groovy.TupleCoder
 
hashCode() - Method in class cz.o2.proxima.beam.util.state.StateOrInput.StateOrInputCoder
 
hashCode() - Method in class cz.o2.proxima.core.repository.AttributeDescriptorBase
 
hashCode() - Method in class cz.o2.proxima.core.repository.AttributeFamilyDescriptor
 
hashCode() - Method in class cz.o2.proxima.core.repository.ConfigRepository
 
hashCode() - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor
 
hashCode() - Method in class cz.o2.proxima.core.repository.EntityDescriptorImpl
 
hashCode() - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.ArrayTypeDescriptor
 
hashCode() - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.EnumTypeDescriptor
 
hashCode() - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.PrimitiveTypeDescriptor
 
hashCode() - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.StructureTypeDescriptor
 
hashCode() - Method in class cz.o2.proxima.core.storage.AbstractStorage
 
hashCode() - Method in class cz.o2.proxima.core.storage.StreamElement
 
hashCode() - Method in class cz.o2.proxima.core.util.NamePattern
 
hashCode() - Method in class cz.o2.proxima.core.util.Pair
 
hashCode() - Method in class cz.o2.proxima.core.util.SerializableScopedValue
 
hashCode() - Method in class cz.o2.proxima.direct.core.DirectAttributeFamilyDescriptor
 
hashCode() - Method in class cz.o2.proxima.direct.core.randomaccess.KeyValue
 
hashCode() - Method in class cz.o2.proxima.direct.io.blob.BlobPath
 
hashCode() - Method in class cz.o2.proxima.direct.io.hadoop.HadoopDataAccessor
 
hasOperator(String) - Method in class cz.o2.proxima.core.repository.Repository
Check if given implementation of data operator is available on classpath and Repository.getOrCreateOperator(Class, Consumer[]) (java.lang.Class, Consumer...)} will return non-null object for class corresponding the given name.
hasPartitionIdForResponse() - Method in class cz.o2.proxima.core.transaction.Response
 
hasSequenceId() - Method in class cz.o2.proxima.core.transaction.Response
 
hasSequentialId() - Method in class cz.o2.proxima.core.storage.StreamElement
 
hasStamp() - Method in class cz.o2.proxima.core.transaction.Response
 
HBaseDataAccessor - Class in cz.o2.proxima.direct.io.hbase
DataAccessor for HBase.
HBaseDataAccessor(EntityDescriptor, URI, Map<String, Object>) - Constructor for class cz.o2.proxima.direct.io.hbase.HBaseDataAccessor
 
HBaseDataAccessor(EntityDescriptor, URI, Map<String, Object>, HBaseDataAccessor.ConfFactory) - Constructor for class cz.o2.proxima.direct.io.hbase.HBaseDataAccessor
 
HBaseDataAccessor.ConfFactory - Interface in cz.o2.proxima.direct.io.hbase
Optional function to be used when creating configuration from URI.
HBaseStorageDescriptor - Class in cz.o2.proxima.direct.io.hbase
A StorageDescriptor for HBase.
HBaseStorageDescriptor() - Constructor for class cz.o2.proxima.direct.io.hbase.HBaseStorageDescriptor
 
houseKeeping() - Method in interface cz.o2.proxima.direct.core.transaction.ServerTransactionManager
Called by the server to signal that the manager should reclaim any resources that are not needed anymore.
houseKeeping() - Method in class cz.o2.proxima.direct.core.transaction.TransactionResourceManager
 
HttpAccessor - Class in cz.o2.proxima.direct.io.http
Accessor for HTTP(s) and websocket URLs.
HttpAccessor(EntityDescriptor, URI, Map<String, Object>) - Constructor for class cz.o2.proxima.direct.io.http.HttpAccessor
 
HttpStorage - Class in cz.o2.proxima.direct.io.http
Storage via HTTP(S) requests.
HttpStorage() - Constructor for class cz.o2.proxima.direct.io.http.HttpStorage
 
HttpWriter - Class in cz.o2.proxima.direct.io.http
Writer via HTTP(S) requests.
HttpWriter(EntityDescriptor, URI, Map<String, Object>) - Constructor for class cz.o2.proxima.direct.io.http.HttpWriter
 

I

identity() - Static method in interface cz.o2.proxima.core.functional.UnaryFunction
Return identity function.
identity() - Static method in interface cz.o2.proxima.core.transform.ElementWiseProxyTransform
 
identity() - Static method in interface cz.o2.proxima.flink.core.ResultExtractor
Create identity extractor, that just returns an input element.
IdentityTransformation - Class in cz.o2.proxima.core.transform
Transform perfoming identity mapping.
IdentityTransformation() - Constructor for class cz.o2.proxima.core.transform.IdentityTransformation
 
idle() - Method in class cz.o2.proxima.core.time.AbstractWatermarkEstimator
Signals that streaming source is idle.
idle() - Method in interface cz.o2.proxima.core.time.WatermarkEstimator
Signals that streaming source is idle.
idle(int) - Method in interface cz.o2.proxima.core.time.PartitionedWatermarkEstimator
Signals that a given partition is idle.
idle(int) - Method in class cz.o2.proxima.direct.core.time.MinimalPartitionWatermarkEstimator
 
idle(long) - Method in interface cz.o2.proxima.core.time.WatermarkIdlePolicy
Signals that a source is idle.
idle(long) - Method in class cz.o2.proxima.direct.core.time.NotProgressingWatermarkIdlePolicy
 
idle(long) - Method in class cz.o2.proxima.direct.core.time.ProcessingTimeShiftingWatermarkIdlePolicy
 
idle(long) - Method in class cz.o2.proxima.direct.core.time.SkewedProcessingTimeIdlePolicy
 
ignoringInterrupted(ExceptionUtils.ThrowingRunnable) - Static method in class cz.o2.proxima.core.util.ExceptionUtils
Run given runnable, swallow any potential InterruptedException and set current thread's interrupted flag (if exception caught).
imports() - Method in interface cz.o2.proxima.core.generator.OperatorGenerator
Retrieve imports for the operator module subclass.
impulse(Closure<T>) - Method in interface cz.o2.proxima.tools.groovy.StreamProvider
Return new WindowedStream that contains single element generated by calling given (parameterless) Closure.
impulse(String, Closure<T>) - Method in class cz.o2.proxima.beam.tools.groovy.BeamStreamProvider
 
impulse(String, Closure<T>) - Method in interface cz.o2.proxima.tools.groovy.StreamProvider
Return new WindowedStream that contains single element generated by calling given (parameterless) Closure.
incomingRequest(String, Request, long, long) - Method in interface cz.o2.proxima.direct.core.transaction.TransactionMonitoringPolicy
Called when new request regarding given transaction is received.
increment() - Method in class cz.o2.proxima.core.metrics.Metric
Increment the metric by one.
increment(double) - Method in class cz.o2.proxima.core.metrics.AbsoluteMetric
 
increment(double) - Method in class cz.o2.proxima.core.metrics.ApproxPercentileMetric
 
increment(double) - Method in class cz.o2.proxima.core.metrics.GaugeMetric
 
increment(double) - Method in class cz.o2.proxima.core.metrics.Metric
Increment the metric by given double value.
increment(double) - Method in class cz.o2.proxima.core.metrics.TimeAveragingMetric
 
ingest(Rpc.Ingest, StreamObserver<Rpc.Status>) - Method in class cz.o2.proxima.direct.server.IngestService
 
ingest(String, String, String, ByteString, Consumer<Rpc.Status>) - Method in class cz.o2.proxima.direct.client.IngestClient
Send ingest request.
ingest(String, String, String, String, ByteString, long, Consumer<Rpc.Status>) - Method in class cz.o2.proxima.direct.client.IngestClient
Send ingest request.
ingest(String, String, String, String, ByteString, Consumer<Rpc.Status>) - Method in class cz.o2.proxima.direct.client.IngestClient
Send ingest request.
INGEST_BULK - Static variable in class cz.o2.proxima.direct.server.metrics.Metrics
 
INGEST_LATENCY - Static variable in class cz.o2.proxima.direct.server.metrics.Metrics
 
INGEST_SINGLE - Static variable in class cz.o2.proxima.direct.server.metrics.Metrics
 
ingestBulk(StreamObserver<Rpc.StatusBulk>) - Method in class cz.o2.proxima.direct.server.IngestService
 
IngestClient - Class in cz.o2.proxima.direct.client
A client being able to connect and write requests to the ingest gateway.
INGESTS - Static variable in class cz.o2.proxima.direct.server.metrics.Metrics
 
IngestServer - Class in cz.o2.proxima.direct.server
The ingestion server.
IngestServer(Config) - Constructor for class cz.o2.proxima.direct.server.IngestServer
 
IngestServer(Config, Repository) - Constructor for class cz.o2.proxima.direct.server.IngestServer
 
IngestService - Class in cz.o2.proxima.direct.server
The ingestion service.
IngestService(Repository, DirectDataOperator, TransactionContext, ScheduledExecutorService) - Constructor for class cz.o2.proxima.direct.server.IngestService
 
ingestsForAttribute(AttributeDescriptor<?>) - Static method in class cz.o2.proxima.direct.server.metrics.Metrics
 
ingestSingle(StreamObserver<Rpc.Status>) - Method in class cz.o2.proxima.direct.server.IngestService
 
init(Repository, String[]) - Method in class cz.o2.proxima.beam.tools.groovy.BeamStreamProvider.Default
 
init(Repository, String[]) - Method in class cz.o2.proxima.beam.tools.groovy.BeamStreamProvider
 
init(Repository, String[]) - Method in interface cz.o2.proxima.tools.groovy.StreamProvider
Initialize the provider with given repository.
init(Configuration) - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementWriteSupport
 
INITIAL_STATEMENT - Static variable in class cz.o2.proxima.tools.groovy.Console
 
initialRestriction(long, boolean) - Static method in class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker.OffsetRange
 
initialRestriction(List<Partition>, long) - Static method in class cz.o2.proxima.beam.core.direct.io.BatchRestrictionTracker.PartitionList
 
initWatermarks(Map<String, Long>) - Method in interface cz.o2.proxima.core.storage.watermark.GlobalWatermarkTracker
Setup parallel consumers.
initWatermarks(Map<String, Long>) - Method in class cz.o2.proxima.core.utils.zookeeper.ZKGlobalWatermarkTracker
 
initWatermarks(Map<String, Long>) - Method in class cz.o2.proxima.flink.utils.FlinkGlobalWatermarkTracker
 
injectJarIntoContextClassLoader(Collection<File>) - Static method in class cz.o2.proxima.beam.util.RunnerUtils
Inject given paths to class loader of given (local) runner.
input(T) - Static method in class cz.o2.proxima.beam.util.state.StateOrInput
 
INSTANCE - Static variable in class cz.o2.proxima.core.storage.PassthroughFilter
 
INSTANCE - Static variable in class cz.o2.proxima.core.storage.ThroughputLimiter.NoOpThroughputLimiter
 
INT - cz.o2.proxima.core.scheme.AttributeValueType
 
IntegerPartition() - Constructor for class cz.o2.proxima.core.storage.Partition.IntegerPartition
 
integers() - Static method in class cz.o2.proxima.core.scheme.SchemaDescriptors
integratePerKey(Closure<K>, Closure<V>, Closure<V>, Closure<V>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Transform this stream to another stream by applying combining transform in global window emitting results after each element added.
integratePerKey(String, Closure<K>, Closure<V>, Closure<V>, Closure<V>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Transform this stream to another stream by applying combining transform in global window emitting results after each element added.
Internal - Annotation Type in cz.o2.proxima.core.annotations
Annotation used to mark type as intended for internal use with no backward compatibility guarantees.
IntSerializer - Class in cz.o2.proxima.core.scheme
A ValueSerializerFactory for integers.
IntSerializer() - Constructor for class cz.o2.proxima.core.scheme.IntSerializer
 
INVALID_REQUEST - Static variable in class cz.o2.proxima.direct.server.metrics.Metrics
 
isAcceptable(AttributeFamilyDescriptor) - Method in interface cz.o2.proxima.direct.core.DataAccessor
Check whether this accessor is acceptable for a given family.
isAcceptable(AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
Checker for kafka topics configuration
isActive() - Method in interface cz.o2.proxima.direct.server.transaction.TransactionContext.Transaction
 
isArrayType() - Method in interface cz.o2.proxima.core.scheme.SchemaDescriptors.SchemaTypeDescriptor
Return true if type is an Array
isAsymmetric() - Method in class cz.o2.proxima.core.repository.AttributeProxyDescriptor
 
isAtHead(ObserveHandle, CommitLogReader) - Static method in class cz.o2.proxima.direct.core.commitlog.ObserveHandleUtils
Check that the given consumer is at current HEAD position in the CommitLogReader.
isBounded() - Method in class cz.o2.proxima.beam.core.direct.io.BatchRestrictionTracker
 
isBounded() - Method in class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker
 
isBounded() - Method in interface cz.o2.proxima.core.storage.Partition
Check if this is bounded or unbounded partition.
isBounded() - Method in class cz.o2.proxima.direct.core.batch.BoundedPartition
 
isBounded() - Method in interface cz.o2.proxima.tools.groovy.Stream
Test if this is bounded stream.
isBulk() - Method in class cz.o2.proxima.direct.io.pubsub.PubSubAccessor
 
isCompatible(WindowFn<?, ?>) - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.DaysWindows
 
isCompatible(WindowFn<?, ?>) - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.MonthsWindows
 
isCompatible(WindowFn<?, ?>) - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.YearsWindows
 
isContextual() - Method in interface cz.o2.proxima.core.transform.ContextualTransformation
 
isContextual() - Method in interface cz.o2.proxima.core.transform.DataOperatorAgnostic
 
isContextual() - Method in interface cz.o2.proxima.core.transform.DataOperatorAware
Verify if this is DataOperator specific (contextual) object.
isDelegateOf(DataOperatorFactory) - Method in class cz.o2.proxima.beam.core.BeamProxyTransform
 
isDelegateOf(DataOperatorFactory) - Method in interface cz.o2.proxima.core.transform.DataOperatorAgnostic
 
isDelegateOf(DataOperatorFactory<?>) - Method in interface cz.o2.proxima.core.transform.DataOperatorAware
Verify if this Transformation belongs to given DataOperatorFactory
isDelegateOf(DataOperatorFactory<?>) - Method in interface cz.o2.proxima.direct.core.transform.DirectElementWiseTransform
 
isDelete() - Method in class cz.o2.proxima.core.storage.StreamElement
Check if this is a delete ingest.
isDeleteWildcard() - Method in class cz.o2.proxima.core.storage.StreamElement
Check if this is a delete wildcard ingest.
isEmpty() - Method in class cz.o2.proxima.beam.core.direct.io.BatchRestrictionTracker.PartitionList
 
isEmpty() - Method in class cz.o2.proxima.core.repository.ConfigRepository
Check if this repository is empty.
isEmpty() - Method in class cz.o2.proxima.core.repository.Repository
Check if this repository is empty.
isEmpty() - Method in class cz.o2.proxima.core.scheme.AttributeValueAccessors.StructureValueImpl
 
isEnumType() - Method in interface cz.o2.proxima.core.scheme.SchemaDescriptors.SchemaTypeDescriptor
Return True if type is an Enum
isFinished() - Method in class cz.o2.proxima.beam.core.direct.io.BatchRestrictionTracker.PartitionList
 
isFinished() - Method in class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker.OffsetRange
Verify that we have processed the whole restriction.
isInitial() - Method in class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker.OffsetRange
 
isInRange(String, long, long) - Method in class cz.o2.proxima.direct.io.bulkfs.DefaultNamingConvention
 
isInRange(String, long, long) - Method in interface cz.o2.proxima.direct.io.bulkfs.NamingConvention
Validate that the given name belongs to given time range.
isInterrupted(Throwable) - Static method in class cz.o2.proxima.core.util.ExceptionUtils
Verify that given Throwable (or any of its causes) is InterruptedException.
isLast() - Method in interface cz.o2.proxima.direct.core.batch.Offset
Is there any other element in the partition?
isLimitConsumed() - Method in class cz.o2.proxima.beam.core.direct.io.BatchRestrictionTracker.PartitionList
 
isLimitConsumed() - Method in class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker.OffsetRange
 
isListPrimaryKey() - Method in interface cz.o2.proxima.core.storage.AccessType
 
isOfType(Class<? extends DataOperator>) - Method in class cz.o2.proxima.beam.core.BeamDataOperatorFactory
 
isOfType(Class<? extends DataOperator>) - Method in interface cz.o2.proxima.core.repository.DataOperatorFactory
Check if the DataOperator produced by this factory is of given class type.
isOfType(Class<? extends DataOperator>) - Method in class cz.o2.proxima.direct.core.DirectDataOperatorFactory
 
isPrimitiveType() - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.ArrayTypeDescriptor
 
isPrimitiveType() - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.PrimitiveTypeDescriptor
 
isPrimitiveType() - Method in interface cz.o2.proxima.core.scheme.SchemaDescriptors.SchemaTypeDescriptor
Return true if type is primitive.
isProxy() - Method in interface cz.o2.proxima.core.repository.AttributeDescriptor
Check if this is a proxy attribute.
isProxy() - Method in class cz.o2.proxima.core.repository.AttributeFamilyDescriptor
Check if this proxied family.
isProxy() - Method in class cz.o2.proxima.core.repository.AttributeFamilyProxyDescriptor
 
isProxy() - Method in class cz.o2.proxima.core.repository.AttributeProxyDescriptor
 
isProxy() - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor
 
isPublic() - Method in interface cz.o2.proxima.core.repository.AttributeDescriptor
Marker if this is a public attribute.
isPublic() - Method in class cz.o2.proxima.core.repository.AttributeDescriptorBase
 
isPublic() - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor
 
isReadonly() - Method in interface cz.o2.proxima.core.storage.AccessType
 
isReadTransform() - Method in interface cz.o2.proxima.core.transform.ElementWiseProxyTransform.ProxySetupContext
 
isReadyForProcessing() - Method in interface cz.o2.proxima.direct.core.batch.ObserveHandle
Verify if we can read without any (known in advance) delays defined by any possible ThroughputLimiter.
isShouldValidate(Repository.Validate) - Method in class cz.o2.proxima.core.repository.ConfigRepository
 
isShouldValidate(Repository.Validate) - Method in class cz.o2.proxima.core.repository.Repository
Check if this Repository should eagerly validate various settings.
isSplittable() - Method in class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker.OffsetRange
Verify that we can split this restriction.
isSplittable() - Method in interface cz.o2.proxima.core.storage.Partition
Verify if this partition can be split into two when reading.
isStateCommitLog() - Method in interface cz.o2.proxima.core.storage.AccessType
 
isStructureType() - Method in interface cz.o2.proxima.core.scheme.SchemaDescriptors.SchemaTypeDescriptor
Return true if type is an structure
isSymmetric() - Method in interface cz.o2.proxima.core.transform.ElementWiseProxyTransform.ProxySetupContext
 
isSystemEntity() - Method in interface cz.o2.proxima.core.repository.EntityDescriptor
 
isTest() - Method in interface cz.o2.proxima.core.transaction.TransactionTransformProvider
true if this provider is intended for tests only.
isTransactional() - Method in interface cz.o2.proxima.core.repository.EntityDescriptor
 
isTransactional() - Method in interface cz.o2.proxima.direct.core.OnlineAttributeWriter
 
isTransactional() - Method in class cz.o2.proxima.direct.core.transaction.TransactionalCachedView
 
isTransactional() - Method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter
 
isUsable() - Method in interface cz.o2.proxima.core.scheme.ValueSerializer
Check if given serializer can be used without exceptions.
isValid(byte[]) - Method in interface cz.o2.proxima.core.scheme.ValueSerializer
Check if given input is valid by trying to parse it.
isWildcard() - Method in interface cz.o2.proxima.core.repository.AttributeDescriptor
Check if this is a wildcard attribute.
isWildcard() - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor
 
isWildcardQuery() - Method in class cz.o2.proxima.core.transaction.KeyAttribute
 
isWriteOnly() - Method in interface cz.o2.proxima.core.storage.AccessType
 
isWriteTransform() - Method in interface cz.o2.proxima.core.transform.ElementWiseProxyTransform.ProxySetupContext
 
iterable(CassandraDBAccessor) - Method in interface cz.o2.proxima.direct.io.cassandra.CqlFactory.KvIterable
 
iterator() - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.ProximaParquetReader
 

J

JavaSerializer - Class in cz.o2.proxima.core.scheme
Value serializer for java classes.
JavaSerializer() - Constructor for class cz.o2.proxima.core.scheme.JavaSerializer
 
JdbcBatchLogReader - Class in cz.o2.proxima.direct.jdbc
 
JdbcBatchLogReader(JdbcDataAccessor, SqlStatementFactory, EntityDescriptor, URI, Factory<ExecutorService>) - Constructor for class cz.o2.proxima.direct.jdbc.JdbcBatchLogReader
 
JdbcDataAccessor - Class in cz.o2.proxima.direct.jdbc
 
JdbcDataAccessor(EntityDescriptor, URI, Map<String, Object>) - Constructor for class cz.o2.proxima.direct.jdbc.JdbcDataAccessor
 
JdbcOnlineAttributeReader - Class in cz.o2.proxima.direct.jdbc
 
JdbcOnlineAttributeReader(JdbcDataAccessor, SqlStatementFactory, EntityDescriptor, URI) - Constructor for class cz.o2.proxima.direct.jdbc.JdbcOnlineAttributeReader
 
JdbcOnlineAttributeWriter - Class in cz.o2.proxima.direct.jdbc
 
JdbcOnlineAttributeWriter(JdbcDataAccessor, SqlStatementFactory, EntityDescriptor, URI) - Constructor for class cz.o2.proxima.direct.jdbc.JdbcOnlineAttributeWriter
 
JdbcStorageDescriptor - Class in cz.o2.proxima.direct.jdbc
 
JdbcStorageDescriptor() - Constructor for class cz.o2.proxima.direct.jdbc.JdbcStorageDescriptor
 
JmxMetricsRegistrar - Class in cz.o2.proxima.core.metrics
 
JmxMetricsRegistrar() - Constructor for class cz.o2.proxima.core.metrics.JmxMetricsRegistrar
 
join(WindowedStream<OTHER>, Closure<K>, Closure<K>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Join with other stream.
join(String, WindowedStream<OTHER>, Closure<K>, Closure<K>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Join with other stream.
JPMSMain - Class in cz.o2.proxima.core.repository
Class that is used as entry point for modularized applications.
json(boolean) - Static method in interface cz.o2.proxima.direct.io.bulkfs.FileFormat
Create json file format.
JsonFormat - Class in cz.o2.proxima.direct.io.bulkfs
Format storing elements as JSON values, one per line.
JsonProtoSerializerFactory - Class in cz.o2.proxima.scheme.proto
Scheme factory for `json-proto` scheme, which transforms json data to same-scheme protobuf.
JsonProtoSerializerFactory() - Constructor for class cz.o2.proxima.scheme.proto.JsonProtoSerializerFactory
 
JsonSerializer - Class in cz.o2.proxima.core.scheme
A serializer of JSON structures.
JsonSerializer() - Constructor for class cz.o2.proxima.core.scheme.JsonSerializer
 

K

KAFKA_CONFIG_PREFIX - Static variable in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
 
KafkaAccessor - Class in cz.o2.proxima.direct.io.kafka
Kafka writer and commit log using KafkaProducer.
KafkaAccessor(EntityDescriptor, URI, Map<String, Object>) - Constructor for class cz.o2.proxima.direct.io.kafka.KafkaAccessor
 
KafkaConsumerFactory<K,​V> - Class in cz.o2.proxima.direct.io.kafka
Factory for KafkaConsumers attached to the given commit log.
KafkaLogReader - Class in cz.o2.proxima.direct.io.kafka
A CommitLogReader implementation for Kafka.
KafkaStorage - Class in cz.o2.proxima.direct.io.kafka
Storage using KafkaProducer.
KafkaStorage() - Constructor for class cz.o2.proxima.direct.io.kafka.KafkaStorage
 
KafkaStreamElement - Class in cz.o2.proxima.direct.io.kafka
Data read from a kafka partition.
KafkaStreamElement.KafkaStreamElementSerializer - Class in cz.o2.proxima.direct.io.kafka
 
KafkaStreamElementSerializer() - Constructor for class cz.o2.proxima.direct.io.kafka.KafkaStreamElement.KafkaStreamElementSerializer
 
KafkaWatermarkConfiguration - Class in cz.o2.proxima.direct.io.kafka
 
KafkaWatermarkConfiguration(Map<String, Object>) - Constructor for class cz.o2.proxima.direct.io.kafka.KafkaWatermarkConfiguration
 
KafkaWriter<K,​V> - Class in cz.o2.proxima.direct.io.kafka
${link OnlineAttributeWriter} implementation for Kafka.
KEY - cz.o2.proxima.core.repository.TransactionMode
Transactional support within the same entity key (i.e.
KeyAttribute - Class in cz.o2.proxima.core.transaction
A combination of key of an entity, attribute descriptor and (optional) specific attribute.
KeyAttribute(EntityDescriptor, String, AttributeDescriptor<?>, long, boolean, String) - Constructor for class cz.o2.proxima.core.transaction.KeyAttribute
 
KeyAttributePartitioner - Class in cz.o2.proxima.core.storage.commitlog
Partitioner based on key-value pairs.
KeyAttributePartitioner() - Constructor for class cz.o2.proxima.core.storage.commitlog.KeyAttributePartitioner
 
KeyAttributes - Class in cz.o2.proxima.core.transaction
 
KeyPartitioner - Class in cz.o2.proxima.core.storage.commitlog
A partitioner based on key of entity.
KeyPartitioner() - Constructor for class cz.o2.proxima.core.storage.commitlog.KeyPartitioner
 
keySerde() - Method in interface cz.o2.proxima.direct.io.kafka.ElementSerializer
Retrieve Serde for type K.
keySerde() - Method in class cz.o2.proxima.direct.io.kafka.KafkaStreamElement.KafkaStreamElementSerializer
 
keySerde() - Method in class cz.o2.proxima.direct.io.kafka.serializer.ValueAsBytesSerializer
 
keySerde() - Method in class cz.o2.proxima.direct.io.kafka.serializer.ValueAsStringSerializer
 
keySet() - Method in class cz.o2.proxima.core.scheme.AttributeValueAccessors.StructureValueImpl
 
KeyValue<T> - Class in cz.o2.proxima.direct.core.randomaccess
KeyValue with Offset.

L

leftJoin(WindowedStream<OTHER>, Closure<K>, Closure<K>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Left join with other stream.
leftJoin(String, WindowedStream<OTHER>, Closure<K>, Closure<K>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Left join with other stream.
LimitedCommitLogReader(CommitLogReader, ThroughputLimiter) - Constructor for class cz.o2.proxima.direct.core.commitlog.CommitLogReaders.LimitedCommitLogReader
 
list() - Method in interface cz.o2.proxima.direct.io.bulkfs.FileSystem
Get all Paths on this FileSystem
list(long, long) - Method in interface cz.o2.proxima.direct.io.bulkfs.FileSystem
Return stream of Paths that represent given time range.
list(long, long) - Method in class cz.o2.proxima.direct.io.gcloud.storage.GCloudFileSystem
 
list(long, long) - Method in class cz.o2.proxima.direct.io.s3.S3FileSystem
 
list(HikariDataSource, RandomOffset, int) - Method in interface cz.o2.proxima.direct.jdbc.SqlStatementFactory
 
list(String, String) - Method in class cz.o2.proxima.tools.io.ConsoleRandomReader
 
list(String, String, String) - Method in class cz.o2.proxima.tools.io.ConsoleRandomReader
 
list(String, String, String, int) - Method in class cz.o2.proxima.tools.io.ConsoleRandomReader
 
list(String, String, String, int, Consumer<KeyValue<?>>) - Method in class cz.o2.proxima.tools.io.ConsoleRandomReader
 
LIST_PRIMARY_KEY - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
LIST_REQUESTS - Static variable in class cz.o2.proxima.direct.server.metrics.Metrics
 
listAttributes(Rpc.ListRequest) - Method in class cz.o2.proxima.direct.client.IngestClient
Send synchronously Rpc.ListRequest to retrieve attributes for entity.
listAttributes(Rpc.ListRequest, StreamObserver<Rpc.ListResponse>) - Method in class cz.o2.proxima.direct.server.RetrieveService
 
listAttributes(String, String) - Method in class cz.o2.proxima.direct.client.IngestClient
Send synchronously Rpc.ListRequest to retrieve attributes for entity.
listAttributes(String, String, String, int) - Method in class cz.o2.proxima.direct.client.IngestClient
Send synchronously Rpc.ListRequest to retrieve attributes for entity.
listEntities(Consumer<Pair<RandomOffset, String>>) - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
List all entity keys.
listEntities(RandomOffset, int, Consumer<Pair<RandomOffset, String>>) - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
List all entity keys with offset and limit.
listEntities(RandomOffset, int, Consumer<Pair<RandomOffset, String>>) - Method in class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
listEntities(RandomOffset, int, Consumer<Pair<RandomOffset, String>>) - Method in class cz.o2.proxima.direct.io.hbase.RandomHBaseReader
 
listEntities(RandomOffset, int, Consumer<Pair<RandomOffset, String>>) - Method in class cz.o2.proxima.direct.jdbc.JdbcOnlineAttributeReader
 
listKeys(String, int) - Method in class cz.o2.proxima.tools.io.ConsoleRandomReader
 
listKeys(Consumer<Pair<RandomOffset, String>>) - Method in class cz.o2.proxima.tools.io.ConsoleRandomReader
 
LIVENESS - Static variable in class cz.o2.proxima.direct.server.metrics.Metrics
 
loadClass(String, boolean) - Method in class cz.o2.proxima.core.util.internal.ClassLoaders.ChildFirstURLClassLoader
 
loadClass(String, boolean) - Method in class cz.o2.proxima.core.util.internal.ClassLoaders.ChildLayerFirstClassLoader
 
loadClassFromSelf(String, boolean) - Method in class cz.o2.proxima.core.util.internal.ClassLoaders.ChildFirstURLClassLoader
 
local(Repository, RepositoryFactory) - Static method in interface cz.o2.proxima.core.repository.RepositoryFactory
 
local(FileSystem, File) - Static method in interface cz.o2.proxima.direct.io.bulkfs.Path
Create a Path representation of the given local file.
local(File, NamingConvention) - Static method in interface cz.o2.proxima.direct.io.bulkfs.FileSystem
 
LOCAL - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
LocalCachedPartitionedView - Class in cz.o2.proxima.direct.core.view
A transformation view from CommitLogReader to CachedView.
LocalCachedPartitionedView(EntityDescriptor, CommitLogReader, OnlineAttributeWriter) - Constructor for class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
LocalCachedPartitionedView(EntityDescriptor, CommitLogReader, OnlineAttributeWriter, long) - Constructor for class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
LocalPath - Class in cz.o2.proxima.direct.io.bulkfs
 
LocalPath(File, FileSystem) - Constructor for class cz.o2.proxima.direct.io.bulkfs.LocalPath
 
LOG_ROLL_INTERVAL - Static variable in class cz.o2.proxima.direct.io.blob.BlobStorageAccessor
How often to roll the blob in milliseconds.
LOG_STALE_COMMIT_INTERVAL_MS - Static variable in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
Log stale commit interval in milliseconds.
LogObserver<OffsetT extends java.io.Serializable,​ContextT extends LogObserver.OnNextContext<OffsetT>> - Interface in cz.o2.proxima.direct.core
Base interface for bulk and online observers.
LogObserver.OnNextContext<OffsetT extends java.io.Serializable> - Interface in cz.o2.proxima.direct.core
LONG - cz.o2.proxima.core.scheme.AttributeValueType
 
longs() - Static method in class cz.o2.proxima.core.scheme.SchemaDescriptors
LongSerializer - Class in cz.o2.proxima.core.scheme
Serializer factory for Longs.
LongSerializer() - Constructor for class cz.o2.proxima.core.scheme.LongSerializer
 

M

main(String[]) - Static method in class cz.o2.proxima.core.repository.JPMSMain
 
main(String[]) - Static method in class cz.o2.proxima.direct.server.IngestServer
Run the server.
main(String[]) - Static method in class cz.o2.proxima.direct.server.ReplicationController
Run the controller.
main(String[]) - Static method in class cz.o2.proxima.direct.transaction.manager.TransactionManagerServer
 
main(String[]) - Static method in class cz.o2.proxima.generator.ModelGenerator
Generate the model from command-line interface.
main(String[]) - Static method in class cz.o2.proxima.tools.groovy.Compiler
 
main(String[]) - Static method in class cz.o2.proxima.tools.groovy.Console
 
MANAGER - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
map(Closure<X>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Remap the stream.
map(Closure<X>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
 
map(String, Closure<X>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Remap the stream.
map(String, Closure<X>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
 
markOffsetAsConsumed() - Method in interface cz.o2.proxima.flink.core.batch.OffsetTrackingBatchLogReader.OffsetCommitter
 
matches(String) - Method in class cz.o2.proxima.core.util.NamePattern
Match input string against the pattern.
max() - Method in class cz.o2.proxima.direct.io.cassandra.DateToLongConverter
 
max() - Method in class cz.o2.proxima.direct.io.cassandra.StringConverter.DefaultConverter
 
max() - Method in interface cz.o2.proxima.direct.io.cassandra.StringConverter
Retrieve maximal element.
MAX_AHEAD_TIME_MS_CFG - Static variable in class cz.o2.proxima.core.storage.watermark.GlobalWatermarkThroughputLimiter
Configuration key for maximum amount of time that a reader can be ahead of a global watermark in milliseconds.
MAX_BYTES_PER_SEC - Static variable in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
Maximal read speed in bytes per second.
MAX_OUT_OF_ORDERNESS_MS - Static variable in class cz.o2.proxima.direct.core.time.BoundedOutOfOrdernessWatermarkEstimator
 
MAX_POLL_RECORDS - Static variable in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
Number of records per poll()
MAX_WATERMARK - Static variable in class cz.o2.proxima.core.time.Watermarks
 
maxAckDeadline - Variable in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubReader
 
Metric<T> - Class in cz.o2.proxima.core.metrics
A single metric.
Metric(String, String) - Constructor for class cz.o2.proxima.core.metrics.Metric
 
MetricFactory - Class in cz.o2.proxima.core.metrics
 
MetricFactory() - Constructor for class cz.o2.proxima.core.metrics.MetricFactory
 
Metrics - Class in cz.o2.proxima.direct.server.metrics
Metrics related to the ingest server.
Metrics - Class in cz.o2.proxima.direct.transaction.manager
 
Metrics() - Constructor for class cz.o2.proxima.direct.transaction.manager.Metrics
 
MetricsRegistrar - Interface in cz.o2.proxima.core.metrics
 
min() - Method in class cz.o2.proxima.direct.io.cassandra.DateToLongConverter
 
min() - Method in class cz.o2.proxima.direct.io.cassandra.StringConverter.DefaultConverter
 
min() - Method in interface cz.o2.proxima.direct.io.cassandra.StringConverter
Retrieve minimal element
MIN_WATERMARK - Static variable in class cz.o2.proxima.core.time.Watermarks
 
MIN_WATERMARK - Static variable in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator
 
MinimalPartitionWatermarkEstimator - Class in cz.o2.proxima.direct.core.time
Watermark estimator wrapper for partitioned sources.
MinimalPartitionWatermarkEstimator(Map<Integer, WatermarkEstimator>) - Constructor for class cz.o2.proxima.direct.core.time.MinimalPartitionWatermarkEstimator
 
minWatermarkOfConsumers() - Static method in class cz.o2.proxima.direct.server.metrics.Metrics
 
ModelGenerator - Class in cz.o2.proxima.generator
Generates code for accessing data of entity and it's attributes.
ModelGenerator(String, String, File, File) - Constructor for class cz.o2.proxima.generator.ModelGenerator
Construct the ModelGenerator.
months(int) - Static method in class cz.o2.proxima.beam.core.transforms.CalendarWindows
Returns a WindowFn that windows elements into periods measured by months.
MultiAccessBuilder - Class in cz.o2.proxima.direct.core.randomaccess
A builder for RandomAccessReader reading from multiple attribute families.
multifetch(Rpc.MultifetchRequest, StreamObserver<Rpc.MultifetchResponse>) - Method in class cz.o2.proxima.direct.server.RetrieveService
 
multiFetch() - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
Return a facade RandomAccessReader.MultiFetch object that can be used to queue multiple requests to the storage and fetch them at once using RandomAccessReader.MultiFetch.fetch(Consumer).

N

nack() - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogObserver.OffsetCommitter
Nack processing (no error thrown, message can be immediately retried).
name - Variable in class cz.o2.proxima.core.repository.AttributeDescriptorBase
 
nameOf(long) - Method in class cz.o2.proxima.direct.io.bulkfs.DefaultNamingConvention
 
nameOf(long) - Method in interface cz.o2.proxima.direct.io.bulkfs.NamingConvention
Convert given timestamp to string representing atomic time range of this naming convention.
NamePattern - Class in cz.o2.proxima.core.util
Pattern matcher for syntax used for patterns in input config.
NamePattern(String) - Constructor for class cz.o2.proxima.core.util.NamePattern
Constructor.
NamingConvention - Interface in cz.o2.proxima.direct.io.bulkfs
Interface wrapping generic convention for naming files.
NamingConventionFactory - Interface in cz.o2.proxima.direct.io.bulkfs
Factory for creating convention for naming files.
newBuilder() - Static method in class cz.o2.proxima.core.repository.AttributeFamilyDescriptor
 
newBuilder() - Static method in interface cz.o2.proxima.core.repository.EntityDescriptor
 
newBuilder() - Static method in class cz.o2.proxima.direct.core.time.BoundedOutOfOrdernessWatermarkEstimator
 
newBuilder() - Static method in class cz.o2.proxima.direct.core.time.ProcessingTimeWatermarkEstimator
 
newBuilder() - Static method in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator
 
newBuilder(Repository) - Static method in interface cz.o2.proxima.core.repository.AttributeDescriptor
 
newBuilder(Repository, ContextProvider) - Static method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
Create a new builder that is able to construct RandomAccessReader from multiple readers responsible for reading from various attribute families.
newConnection(URL) - Method in class cz.o2.proxima.direct.io.http.TestableConnFactory
 
NEWEST - cz.o2.proxima.core.storage.commitlog.Position
Read the commit log from the current data actually pushed to the log or the currently committed position.
newInstance(Class<T>) - Static method in class cz.o2.proxima.core.util.Classpath
Create new instance of given class
newInstance(String, Class<T>) - Static method in class cz.o2.proxima.core.util.Classpath
Create new instance of given class
newPath(long) - Method in interface cz.o2.proxima.direct.io.bulkfs.FileSystem
Create new Path.
newPath(long) - Method in class cz.o2.proxima.direct.io.gcloud.storage.GCloudFileSystem
 
newPath(long) - Method in class cz.o2.proxima.direct.io.s3.S3FileSystem
 
newProxy(String, AttributeDescriptor<T>, ProxyTransform, AttributeDescriptor<T>, ProxyTransform, boolean, URI, ValueSerializer<T>) - Static method in interface cz.o2.proxima.core.repository.AttributeDescriptor
 
newProxy(String, AttributeDescriptor<T>, ProxyTransform, AttributeDescriptor<T>, ProxyTransform, URI, ValueSerializer<T>) - Static method in interface cz.o2.proxima.core.repository.AttributeDescriptor
 
newTracker() - Method in class cz.o2.proxima.beam.core.direct.io.BatchRestrictionTracker.PartitionList
 
newTracker() - Method in class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker.OffsetRange
 
NON_COMMIT_LOG_DELETES - Static variable in class cz.o2.proxima.direct.server.metrics.Metrics
 
NON_COMMIT_LOG_UPDATES - Static variable in class cz.o2.proxima.direct.server.metrics.Metrics
 
NON_COMMIT_WRITES_RETRIES - Static variable in class cz.o2.proxima.direct.server.metrics.Metrics
 
NON_TRANSACTIONAL - cz.o2.proxima.core.repository.TransformationDescriptor.InputTransactionMode
None of the input attributes is transactional attribute.
NonContextual(DirectDataOperator, String, ElementWiseTransformation, boolean, StorageFilter) - Constructor for class cz.o2.proxima.direct.core.transform.TransformationObserver.NonContextual
 
NONE - cz.o2.proxima.core.repository.Repository.Validate
Do not perform any validations.
NONE - cz.o2.proxima.core.repository.TransactionMode
No transactional support.
NONE - cz.o2.proxima.core.transaction.Request.Flags
 
NONE - cz.o2.proxima.core.transaction.Response.Flags
 
noop() - Static method in interface cz.o2.proxima.direct.core.batch.ObserveHandle
 
noop() - Static method in interface cz.o2.proxima.direct.core.CommitCallback
 
NoOpThroughputLimiter() - Constructor for class cz.o2.proxima.core.storage.ThroughputLimiter.NoOpThroughputLimiter
 
nop() - Static method in interface cz.o2.proxima.direct.core.transaction.TransactionMonitoringPolicy
 
normalizePath(String) - Static method in class cz.o2.proxima.direct.io.blob.BlobPath
 
NotProgressingWatermarkIdlePolicy - Class in cz.o2.proxima.direct.core.time
Idle policy doesn't progress watermark on idle.
NotProgressingWatermarkIdlePolicy() - Constructor for class cz.o2.proxima.direct.core.time.NotProgressingWatermarkIdlePolicy
 
NotProgressingWatermarkIdlePolicy.Factory - Class in cz.o2.proxima.direct.core.time
 

O

observe(String, Position, CommitLogObserver) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Subscribe observer by name to the commit log.
observe(String, Position, CommitLogObserver) - Method in class cz.o2.proxima.direct.core.commitlog.CommitLogReaders.LimitedCommitLogReader
 
observe(String, Position, CommitLogObserver) - Method in class cz.o2.proxima.direct.io.http.WebsocketReader
 
observe(String, Position, CommitLogObserver) - Method in class cz.o2.proxima.direct.io.kafka.KafkaLogReader
Subscribe observer by name to the commit log.
observe(String, Position, CommitLogObserver) - Method in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubReader
 
observe(String, CommitLogObserver) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Subscribe observer by name to the commit log and read the newest data.
observe(List<Partition>, List<AttributeDescriptor<?>>, BatchLogObserver) - Method in interface cz.o2.proxima.direct.core.batch.BatchLogReader
Observe data stored in given partitions.
observe(List<Partition>, List<AttributeDescriptor<?>>, BatchLogObserver) - Method in class cz.o2.proxima.direct.io.blob.BlobLogReader
 
observe(List<Partition>, List<AttributeDescriptor<?>>, BatchLogObserver) - Method in class cz.o2.proxima.direct.io.hadoop.HadoopBatchLogReader
 
observe(List<Partition>, List<AttributeDescriptor<?>>, BatchLogObserver) - Method in class cz.o2.proxima.direct.jdbc.JdbcBatchLogReader
 
observe(List<Partition>, List<AttributeDescriptor<?>>, BatchLogObserver) - Method in class cz.o2.proxima.flink.core.batch.OffsetTrackingBatchLogReader
 
observeBulk(String, Position, boolean, CommitLogObserver) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Subscribe to the commit log in a bulk fashion.
observeBulk(String, Position, boolean, CommitLogObserver) - Method in class cz.o2.proxima.direct.core.commitlog.CommitLogReaders.LimitedCommitLogReader
 
observeBulk(String, Position, boolean, CommitLogObserver) - Method in class cz.o2.proxima.direct.io.http.WebsocketReader
 
observeBulk(String, Position, boolean, CommitLogObserver) - Method in class cz.o2.proxima.direct.io.kafka.KafkaLogReader
 
observeBulk(String, Position, boolean, CommitLogObserver) - Method in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubReader
Observe PubSub in a bulk fashion.
observeBulk(String, Position, CommitLogObserver) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Subscribe to the commit log in a bulk fashion.
observeBulk(String, CommitLogObserver) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Subscribe to the commit log in a bulk fashion from newest data.
observeBulkOffsets(Collection<Offset>, boolean, CommitLogObserver) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Consume from given offsets in a bulk fashion.
observeBulkOffsets(Collection<Offset>, boolean, CommitLogObserver) - Method in class cz.o2.proxima.direct.core.commitlog.CommitLogReaders.LimitedCommitLogReader
 
observeBulkOffsets(Collection<Offset>, boolean, CommitLogObserver) - Method in class cz.o2.proxima.direct.io.http.WebsocketReader
 
observeBulkOffsets(Collection<Offset>, boolean, CommitLogObserver) - Method in class cz.o2.proxima.direct.io.kafka.KafkaLogReader
 
observeBulkOffsets(Collection<Offset>, boolean, CommitLogObserver) - Method in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubReader
 
observeBulkOffsets(Collection<Offset>, CommitLogObserver) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Consume from given offsets in a bulk fashion.
observeBulkPartitions(String, Collection<Partition>, Position, boolean, CommitLogObserver) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Subscribe to given partitions in a bulk fashion.
observeBulkPartitions(String, Collection<Partition>, Position, boolean, CommitLogObserver) - Method in class cz.o2.proxima.direct.core.commitlog.CommitLogReaders.LimitedCommitLogReader
 
observeBulkPartitions(String, Collection<Partition>, Position, boolean, CommitLogObserver) - Method in class cz.o2.proxima.direct.io.http.WebsocketReader
 
observeBulkPartitions(String, Collection<Partition>, Position, boolean, CommitLogObserver) - Method in class cz.o2.proxima.direct.io.kafka.KafkaLogReader
 
observeBulkPartitions(String, Collection<Partition>, Position, boolean, CommitLogObserver) - Method in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubReader
 
observeBulkPartitions(String, Collection<Partition>, Position, CommitLogObserver) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Subscribe to given partitions in a bulk fashion.
observeBulkPartitions(Collection<Partition>, Position, boolean, CommitLogObserver) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Subscribe to given partitions in a bulk fashion.
observeBulkPartitions(Collection<Partition>, Position, CommitLogObserver) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Subscribe to given partitions in a bulk fashion.
ObserveHandle - Interface in cz.o2.proxima.direct.core.batch
A interface for handling progress and control consumption of running observe process.
ObserveHandle - Interface in cz.o2.proxima.direct.core.commitlog
A interface for handling progress and control consumption of running observe process.
ObserveHandleUtils - Class in cz.o2.proxima.direct.core.commitlog
 
observeOffsets(List<Offset>, List<AttributeDescriptor<?>>, BatchLogObserver) - Method in interface cz.o2.proxima.direct.core.batch.BatchLogReader
Observe data stored in given partitions for a given offsets.
observePartitions(String, Collection<Partition>, Position, boolean, CommitLogObserver) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Subscribe to given set of partitions.
observePartitions(String, Collection<Partition>, Position, boolean, CommitLogObserver) - Method in class cz.o2.proxima.direct.core.commitlog.CommitLogReaders.LimitedCommitLogReader
 
observePartitions(String, Collection<Partition>, Position, boolean, CommitLogObserver) - Method in class cz.o2.proxima.direct.io.http.WebsocketReader
 
observePartitions(String, Collection<Partition>, Position, boolean, CommitLogObserver) - Method in class cz.o2.proxima.direct.io.kafka.KafkaLogReader
 
observePartitions(String, Collection<Partition>, Position, boolean, CommitLogObserver) - Method in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubReader
 
observePartitions(Collection<Partition>, Position, boolean, CommitLogObserver) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Subscribe to given set of partitions.
observePartitions(Collection<Partition>, Position, CommitLogObserver) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Subscribe to given set of partitions.
observePartitions(Collection<Partition>, CommitLogObserver) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Subscribe to given set of partitions and read newest data.
ObserverUtils - Class in cz.o2.proxima.direct.core.commitlog
Various utilities for working with CommitLogObserver.
of() - Static method in class cz.o2.proxima.beam.tools.groovy.TupleCoder
 
of(int) - Static method in interface cz.o2.proxima.core.storage.Partition
Wrap numerical id to Partition object.
of(A, B) - Static method in class cz.o2.proxima.core.util.Pair
 
of(UnaryFunction<T, V>, UnaryFunction<V, T>) - Static method in interface cz.o2.proxima.core.scheme.AttributeValueAccessors.PrimitiveValueAccessor
Create accessor with conversion functions.
of(AttributeFamilyProxyDescriptor, DataAccessor, DataAccessor) - Static method in class cz.o2.proxima.beam.core.AttributeFamilyProxyDataAccessor
 
of(ConfigRepository) - Static method in class cz.o2.proxima.direct.transaction.manager.TransactionManagerServer
 
of(EntityDescriptor, AttributeDescriptor<T>) - Static method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Regular
 
of(EntityDescriptor, AttributeDescriptor<T>) - Static method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Wildcard
 
of(EntityDescriptor, AttributeDescriptor<T>, long, String, String, RandomOffset, byte[], long) - Static method in class cz.o2.proxima.direct.core.randomaccess.KeyValue
 
of(EntityDescriptor, AttributeDescriptor<T>, long, String, String, RandomOffset, T, byte[], long) - Static method in class cz.o2.proxima.direct.core.randomaccess.KeyValue
 
of(EntityDescriptor, AttributeDescriptor<T>, String, String, RandomOffset, byte[]) - Static method in class cz.o2.proxima.direct.core.randomaccess.KeyValue
 
of(EntityDescriptor, AttributeDescriptor<T>, String, String, RandomOffset, byte[], long) - Static method in class cz.o2.proxima.direct.core.randomaccess.KeyValue
 
of(EntityDescriptor, AttributeDescriptor<T>, String, String, RandomOffset, T, byte[]) - Static method in class cz.o2.proxima.direct.core.randomaccess.KeyValue
 
of(EntityDescriptor, AttributeDescriptor<T>, String, String, RandomOffset, T, byte[], long) - Static method in class cz.o2.proxima.direct.core.randomaccess.KeyValue
 
of(Repository) - Static method in class cz.o2.proxima.beam.core.io.AttributeDescriptorCoder
of(Repository) - Static method in class cz.o2.proxima.beam.core.io.EntityDescriptorCoder
Construct the coder from repository
of(Repository) - Static method in class cz.o2.proxima.beam.core.io.SchemaStreamElementCoder
 
of(Repository) - Static method in class cz.o2.proxima.beam.core.io.StreamElementCoder
Create coder for StreamElements originating in given Repository.
of(Repository) - Static method in class cz.o2.proxima.direct.server.ReplicationController
Constructs a new ReplicationController.
of(RepositoryFactory) - Static method in class cz.o2.proxima.beam.core.io.AttributeDescriptorCoder
of(RepositoryFactory) - Static method in class cz.o2.proxima.beam.core.io.EntityDescriptorCoder
Construct the coder from repository factory
of(RepositoryFactory) - Static method in class cz.o2.proxima.beam.core.io.StreamElementCoder
Create coder for StreamElements originating in given Repository.
of(RepositoryFactory, BatchLogReader, List<AttributeDescriptor<?>>, long, long, Map<String, Object>) - Static method in class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource
 
of(Repository, Class<T>) - Static method in class cz.o2.proxima.core.storage.internal.DataAccessorLoader
 
of(Repository, Class<T>, ModuleLayer) - Static method in class cz.o2.proxima.core.storage.internal.DataAccessorLoader
 
of(AttributeValueAccessor<T, V>) - Static method in interface cz.o2.proxima.core.scheme.AttributeValueAccessors.ArrayValueAccessor
Create new array accessor
of(Partition, long, boolean) - Static method in interface cz.o2.proxima.direct.core.batch.Offset
Construct an immutable offset from given values.
of(BatchLogReader) - Static method in class cz.o2.proxima.flink.core.batch.OffsetTrackingBatchLogReader
Wrap batch log reader into OffsetTrackingBatchLogReader.
of(Context, S3FileSystem, String) - Static method in class cz.o2.proxima.direct.io.s3.S3BlobPath
 
of(Context, S3FileSystem, String, long) - Static method in class cz.o2.proxima.direct.io.s3.S3BlobPath
 
of(DirectDataOperator, OnlineAttributeWriter) - Static method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter
 
of(FileSystem, Blob) - Static method in class cz.o2.proxima.direct.io.gcloud.storage.GCloudBlobPath
 
of(FileSystem, GCloudBlobPath.GCloudBlob) - Static method in class cz.o2.proxima.direct.io.gcloud.storage.GCloudBlobPath
 
of(Config) - Static method in class cz.o2.proxima.core.repository.ConfigRepository.Builder
Create new Repository from Config.
of(Config) - Static method in class cz.o2.proxima.core.repository.ConfigRepository
Create config from /Config.
of(Config) - Static method in class cz.o2.proxima.core.repository.Repository
Create Repository from given Config.
of(Config) - Static method in class cz.o2.proxima.direct.transaction.manager.TransactionManagerServer
 
of(String) - Static method in enum cz.o2.proxima.core.storage.StorageType
 
of(String, Position, long, RepositoryFactory, CommitLogReader) - Static method in class cz.o2.proxima.beam.core.direct.io.CommitLogRead
Create the CommitLogRead transform.
of(String, Position, long, Repository, CommitLogReader) - Static method in class cz.o2.proxima.beam.core.direct.io.CommitLogRead
Create the CommitLogRead transform.
of(String, String, AttributeDescriptor<T>, long) - Static method in class cz.o2.proxima.direct.core.randomaccess.RandomAccessReader.GetRequest
 
of(String, String, String, String) - Static method in interface cz.o2.proxima.core.transaction.TransactionSerializerSchemeProvider
 
of(List<AttributeDescriptor<?>>, long, RepositoryFactory, BatchLogReader, long, long, Map<String, Object>) - Static method in class cz.o2.proxima.beam.core.direct.io.BatchLogRead
Create the BatchLogRead transform that reads from BatchLogReader in batch manner.
of(List<AttributeDescriptor<?>>, long, Repository, BatchLogReader) - Static method in class cz.o2.proxima.beam.core.direct.io.BatchLogRead
Create the BatchLogRead transform that reads from BatchLogReader in batch manner.
of(List<AttributeDescriptor<?>>, long, Repository, BatchLogReader, long, long) - Static method in class cz.o2.proxima.beam.core.direct.io.BatchLogRead
Create the BatchLogRead transform that reads from BatchLogReader in batch manner.
of(Map<String, Object>) - Static method in interface cz.o2.proxima.core.scheme.AttributeValueAccessors.StructureValue
Create structure value from map.
of(Coder<K>, Coder<V>) - Static method in class cz.o2.proxima.beam.core.io.PairCoder
 
of(KryoCoder<Object>) - Static method in class cz.o2.proxima.beam.tools.groovy.TupleCoder
 
ofAttributeDescriptor(EntityDescriptor, String, AttributeDescriptor<?>, long) - Static method in class cz.o2.proxima.core.transaction.KeyAttributes
Create KeyAttribute for given entity, key and attribute descriptor.
ofAttributeDescriptor(EntityDescriptor, String, AttributeDescriptor<?>, long, String) - Static method in class cz.o2.proxima.core.transaction.KeyAttributes
Create KeyAttribute for given entity, key and attribute descriptor.
ofBounded(String, long, RepositoryFactory, CommitLogReader) - Static method in class cz.o2.proxima.beam.core.direct.io.CommitLogRead
Create the CommitLogRead transform.
Offset - Interface in cz.o2.proxima.direct.core.batch
Offset representing a "pointer" to an element within a batch partition.
Offset - Interface in cz.o2.proxima.direct.core.commitlog
Interface for implementations and their offset.
Offset.SimpleOffset - Class in cz.o2.proxima.direct.core.batch
 
OffsetCommitter<ID> - Class in cz.o2.proxima.direct.io.kafka
A committer of kafka offsets.
OffsetCommitter() - Constructor for class cz.o2.proxima.direct.io.kafka.OffsetCommitter
 
OffsetCommitter(long, long) - Constructor for class cz.o2.proxima.direct.io.kafka.OffsetCommitter
 
OffsetCommitter.Callback - Interface in cz.o2.proxima.direct.io.kafka
Callback to be called for performing the commit.
OffsetExternalizer - Interface in cz.o2.proxima.direct.core.commitlog
Interface provides methods for serializing commit log offset Offset to external formats.
OffsetRange(Offset, Offset, long, boolean, long) - Constructor for class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker.OffsetRange
 
OffsetRestrictionTracker - Class in cz.o2.proxima.beam.core.direct.io
A RestrictionTracker for Offsets read from CommitLogReader
OffsetRestrictionTracker.OffsetRange - Class in cz.o2.proxima.beam.core.direct.io
 
Offsets - Class in cz.o2.proxima.direct.io.cassandra
Offset based on token function.
Offsets - Class in cz.o2.proxima.direct.jdbc
 
Offsets.Raw - Class in cz.o2.proxima.direct.io.cassandra
Offset represented by the raw string value.
Offsets.Raw - Class in cz.o2.proxima.direct.jdbc
 
Offsets.Token - Class in cz.o2.proxima.direct.io.cassandra
Offset represented by a token (hash) of the key.
OffsetTrackingBatchLogObserver(BatchLogObserver) - Constructor for class cz.o2.proxima.flink.core.batch.OffsetTrackingBatchLogReader.OffsetTrackingBatchLogObserver
 
OffsetTrackingBatchLogReader - Class in cz.o2.proxima.flink.core.batch
A simple wrapper for batch log reader, that is able to track the "highest" consumed offset for each partition.
OffsetTrackingBatchLogReader(BatchLogReader) - Constructor for class cz.o2.proxima.flink.core.batch.OffsetTrackingBatchLogReader
 
OffsetTrackingBatchLogReader.OffsetCommitter - Interface in cz.o2.proxima.flink.core.batch
 
OffsetTrackingBatchLogReader.OffsetTrackingBatchLogObserver - Class in cz.o2.proxima.flink.core.batch
Log observer, that keeps track of the "highest" consumed offset for each partition.
OffsetTrackingBatchLogReader.OffsetTrackingObserveHandle - Interface in cz.o2.proxima.flink.core.batch
Batch observe handle, that has access to consumed offsets.
ofMissingAttribute(EntityDescriptor, String, AttributeDescriptor<?>) - Static method in class cz.o2.proxima.core.transaction.KeyAttributes
Create KeyAttribute for given entity, key and attribute descriptor.
ofMissingAttribute(EntityDescriptor, String, AttributeDescriptor<?>, String) - Static method in class cz.o2.proxima.core.transaction.KeyAttributes
Create KeyAttribute for given entity, key and attribute descriptor.
ofSinglePartition(Partition, long) - Static method in class cz.o2.proxima.beam.core.direct.io.BatchRestrictionTracker.PartitionList
Create BatchRestrictionTracker.PartitionList with given limit containing only single Partition
ofStreamElement(StreamElement) - Static method in class cz.o2.proxima.core.transaction.KeyAttributes
Create a KeyAttribute for given StreamElement.
ofTest(Config) - Static method in class cz.o2.proxima.core.repository.ConfigRepository.Builder
Create a test version of repository.
ofTest(Config, Repository.Validate...) - Static method in class cz.o2.proxima.core.repository.ConfigRepository
Construct default repository from the config.
ofTest(Config, Repository.Validate...) - Static method in class cz.o2.proxima.core.repository.Repository
Create Repository from given Config for testing purposes.
ofWildcardQueryElements(EntityDescriptor, String, AttributeDescriptor<?>, Iterable<E>) - Static method in class cz.o2.proxima.core.transaction.KeyAttributes
Create a list of KeyAttributes that represent a query for wildcard attribute and the returned
OLDEST - cz.o2.proxima.core.storage.commitlog.Position
Read the commit log from the oldest data available.
onCache(StreamElement, boolean) - Method in class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
onCancelled() - Method in interface cz.o2.proxima.direct.core.LogObserver
Notify that the processing has been canceled.
onCancelled() - Method in class cz.o2.proxima.direct.core.transaction.ThreadPooledObserver
 
onCancelled() - Method in class cz.o2.proxima.flink.core.batch.OffsetTrackingBatchLogReader.OffsetTrackingBatchLogObserver
 
onCompleted() - Method in interface cz.o2.proxima.direct.core.LogObserver
Notify that the processing has gracefully ended.
onCompleted() - Method in class cz.o2.proxima.direct.core.transaction.ThreadPooledObserver
 
onCompleted() - Method in class cz.o2.proxima.flink.core.batch.OffsetTrackingBatchLogReader.OffsetTrackingBatchLogObserver
 
onError(Throwable) - Method in interface cz.o2.proxima.direct.core.LogObserver
Called to notify there was an error in the commit reader.
onError(Throwable) - Method in class cz.o2.proxima.direct.core.transaction.ThreadPooledObserver
 
onError(Throwable) - Method in class cz.o2.proxima.direct.core.transform.TransformationObserver
 
onError(Throwable) - Method in class cz.o2.proxima.direct.transaction.manager.TransactionLogObserver
 
onError(Throwable) - Method in class cz.o2.proxima.flink.core.batch.OffsetTrackingBatchLogReader.OffsetTrackingBatchLogObserver
 
onException(Exception) - Method in interface cz.o2.proxima.direct.core.LogObserver
Called to notify there was an exception in the commit reader.
onFatalError(Error) - Method in interface cz.o2.proxima.direct.core.LogObserver
Called to notify there was an error in the commit reader.
onFatalError(Throwable) - Method in class cz.o2.proxima.direct.core.transform.TransformationObserver
 
onIdle(CommitLogObserver.OnIdleContext) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogObserver
Called when the observer is idle.
onIdle(CommitLogObserver.OnIdleContext) - Method in class cz.o2.proxima.direct.core.transaction.ThreadPooledObserver
 
onIdle(CommitLogObserver.OnIdleContext) - Method in class cz.o2.proxima.direct.core.transform.TransformationObserver
 
onIdle(CommitLogObserver.OnIdleContext) - Method in class cz.o2.proxima.direct.transaction.manager.TransactionLogObserver
 
onInterrupted() - Method in interface cz.o2.proxima.direct.core.batch.BatchLogObserver
Called when the consumption is cancelled in case BatchLogObserver.onNext(StreamElement, OnNextContext) method is blocked and should be interrupted.
online() - Method in interface cz.o2.proxima.direct.core.AttributeWriterBase
Cast this to OnlineAttributeWriter.
online() - Method in class cz.o2.proxima.direct.core.transaction.TransactionalCachedView
 
ONLINE - cz.o2.proxima.direct.core.AttributeWriterBase.Type
 
OnlineAttributeWriter - Interface in cz.o2.proxima.direct.core
Writer for attribute values.
OnlineAttributeWriter.Factory<T extends OnlineAttributeWriter> - Interface in cz.o2.proxima.direct.core
Serializable factory for OnlineAttributeWriter.
OnlineAttributeWriters - Class in cz.o2.proxima.direct.core
 
onNext(StreamElement) - Method in interface cz.o2.proxima.direct.core.batch.BatchLogObserver
Read next data from the batch storage.
onNext(StreamElement, ContextT) - Method in interface cz.o2.proxima.direct.core.LogObserver
Process next record in the commit log.
onNext(StreamElement, BatchLogObserver.OnNextContext) - Method in interface cz.o2.proxima.direct.core.batch.BatchLogObserver
 
onNext(StreamElement, BatchLogObserver.OnNextContext) - Method in class cz.o2.proxima.flink.core.batch.OffsetTrackingBatchLogReader.OffsetTrackingBatchLogObserver
 
onNext(StreamElement, CommitLogObserver.OnNextContext) - Method in class cz.o2.proxima.direct.core.transaction.ThreadPooledObserver
 
onNext(StreamElement, CommitLogObserver.OnNextContext) - Method in class cz.o2.proxima.direct.core.transform.TransformationObserver
 
onNext(StreamElement, CommitLogObserver.OnNextContext) - Method in class cz.o2.proxima.direct.transaction.manager.TransactionLogObserver
 
onRepartition(CommitLogObserver.OnRepartitionContext) - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogObserver
Callback to notify of automatic repartitioning.
onRepartition(CommitLogObserver.OnRepartitionContext) - Method in class cz.o2.proxima.direct.core.transaction.ThreadPooledObserver
 
onRepartition(CommitLogObserver.OnRepartitionContext) - Method in class cz.o2.proxima.direct.core.transform.TransformationObserver.Contextual
 
onReplicated(StreamElement) - Method in class cz.o2.proxima.direct.core.transform.TransformationObserver
 
onRestart() - Method in interface cz.o2.proxima.core.transform.ContextualTransformation
Called before starting processing after fresh start of processing or after recovery from error
open(long, long) - Method in class cz.o2.proxima.core.transaction.Response
Create response for open transaction.
open(long, long, Collection<KeyAttribute>) - Static method in class cz.o2.proxima.core.transaction.State
 
OPEN - cz.o2.proxima.core.transaction.Request.Flags
 
OPEN - cz.o2.proxima.core.transaction.Response.Flags
 
OPEN - cz.o2.proxima.core.transaction.State.Flags
 
openConnection(URI, StreamElement) - Method in interface cz.o2.proxima.direct.io.http.ConnFactory
Open and return HTTP(S) connection to given base URI with given input stream element.
openConnection(URI, StreamElement) - Method in class cz.o2.proxima.direct.io.http.opentsdb.OpenTsdbConnectionFactory
 
openReader(Path, EntityDescriptor) - Method in interface cz.o2.proxima.direct.io.bulkfs.FileFormat
Open reader for data stored at given Path
openReader(Path, EntityDescriptor) - Method in class cz.o2.proxima.direct.io.bulkfs.JsonFormat
 
openReader(Path, EntityDescriptor) - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.ParquetFileFormat
 
OpenTsdbConnectionFactory - Class in cz.o2.proxima.direct.io.http.opentsdb
A ConnFactory for OpenTSDB.
OpenTsdbConnectionFactory() - Constructor for class cz.o2.proxima.direct.io.http.opentsdb.OpenTsdbConnectionFactory
 
OpenTsdbWriter - Class in cz.o2.proxima.direct.io.http.opentsdb
A HttpWriter specialized on opentsdb.
OpenTsdbWriter(EntityDescriptor, URI, Map<String, Object>) - Constructor for class cz.o2.proxima.direct.io.http.opentsdb.OpenTsdbWriter
 
openWriter(Path, EntityDescriptor) - Method in interface cz.o2.proxima.direct.io.bulkfs.FileFormat
Open writer for data on given Path.
openWriter(Path, EntityDescriptor) - Method in class cz.o2.proxima.direct.io.bulkfs.JsonFormat
 
openWriter(Path, EntityDescriptor) - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.ParquetFileFormat
 
operatorFactory() - Method in interface cz.o2.proxima.core.generator.OperatorGenerator
Retrieve DataOperatorFactory associated with this generator.
OperatorGenerator - Interface in cz.o2.proxima.core.generator
Factory for DataOperator specific enhancements to generated model.
OperatorGeneratorFactory - Interface in cz.o2.proxima.core.generator
Factory for OperatorGenerator.
Optionals - Class in cz.o2.proxima.core.util
 
Options - Class in cz.o2.proxima.direct.client
Client related options.
Options() - Constructor for class cz.o2.proxima.direct.client.Options
 
or(AccessType, AccessType) - Static method in interface cz.o2.proxima.core.storage.AccessType
 
OrFilter(List<StorageFilter>) - Constructor for class cz.o2.proxima.core.storage.StorageFilter.OrFilter
 
outgoingResponse(String, Response) - Method in interface cz.o2.proxima.direct.core.transaction.TransactionMonitoringPolicy
Called when a response to transaction client is about to be sent.
outputs(Collection<Commit.TransactionUpdate>, Collection<StreamElement>) - Static method in class cz.o2.proxima.core.transaction.Commit
Create new Commit message to be appended to _transcation.commit

P

Pair<A,​B> - Class in cz.o2.proxima.core.util
A generic pair (tuple).
PairCoder<K,​V> - Class in cz.o2.proxima.beam.core.io
A coder for Pairs.
PARQUET_CONFIG_COMPRESSION_KEY_NAME - Static variable in class cz.o2.proxima.direct.io.bulkfs.parquet.ParquetFileFormat
Config key specified compression used in parquet writer.
PARQUET_CONFIG_PAGE_SIZE_KEY_NAME - Static variable in class cz.o2.proxima.direct.io.bulkfs.parquet.ParquetFileFormat
Config key specified page and row group size in parquet writer.
PARQUET_CONFIG_VALUES_PREFIX_KEY_NAME - Static variable in class cz.o2.proxima.direct.io.bulkfs.parquet.ParquetFileFormat
Config key used for attribute prefix - useful when attribute name collides with proxima fields defined as PARQUET_COLUMN_NAME_*
PARQUET_DEFAULT_PAGE_SIZE - Static variable in class cz.o2.proxima.direct.io.bulkfs.parquet.ParquetFileFormat
Default page size used for parquet writer
PARQUET_DEFAULT_VALUES_NAME_PREFIX - Static variable in class cz.o2.proxima.direct.io.bulkfs.parquet.ParquetFileFormat
Default attribute prefix.
PARQUET_MESSAGE_NAME - Static variable in class cz.o2.proxima.direct.io.bulkfs.parquet.ParquetFileFormat
Name for top level message in parquet schema.
ParquetColumn() - Constructor for class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementMaterializer.ParquetColumnGroup.ParquetColumn
 
ParquetColumnGroup() - Constructor for class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementMaterializer.ParquetColumnGroup
 
ParquetColumnListGroup() - Constructor for class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementMaterializer.ParquetColumnListGroup
 
ParquetColumnListRecordConverter(GroupType, String, StreamElementMaterializer.ParquetColumnRecordConverter) - Constructor for class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementMaterializer.ParquetColumnListRecordConverter
 
ParquetColumnRecordConverter(GroupType, String, StreamElementMaterializer.ParquetColumnRecordConverter) - Constructor for class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementMaterializer.ParquetColumnRecordConverter
 
ParquetFileFormat - Class in cz.o2.proxima.direct.io.bulkfs.parquet
Bulk file format which stored data in Parquet format.
ParquetFileFormat() - Constructor for class cz.o2.proxima.direct.io.bulkfs.parquet.ParquetFileFormat
 
parsed() - Static method in interface cz.o2.proxima.flink.core.ResultExtractor
Create an extractor, that just extracts parsed value from a stream element.
parseElements(PubsubMessage) - Method in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubReader
 
parseElements(PubsubMessage) - Method in class cz.o2.proxima.direct.io.pubsub.PubSubBulkReader
 
parseIndexName(URI) - Static method in class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchAccessor
 
parseMinMaxTimestamp(String) - Method in class cz.o2.proxima.direct.io.bulkfs.DefaultNamingConvention
 
parseMinMaxTimestamp(String) - Method in interface cz.o2.proxima.direct.io.bulkfs.NamingConvention
Parse min and max timestamp from given string.
parsePath(URI) - Static method in class cz.o2.proxima.core.storage.UriUtil
Parse path from URI
parseQuery(URI) - Static method in class cz.o2.proxima.core.storage.UriUtil
Parse query string from URI
Partition - Interface in cz.o2.proxima.core.storage
Interface representing a partition of the commit log.
PARTITION_MAX_BLOBS - Static variable in class cz.o2.proxima.direct.io.blob.BlobStorageAccessor
Maximal number of blobs to be put in single partition.
PARTITION_MAX_TIME_SPAN_MS - Static variable in class cz.o2.proxima.direct.io.blob.BlobStorageAccessor
Maximal amount of time (in milliseconds) a partition containing multiple blobs can span.
PARTITION_SIZE - Static variable in class cz.o2.proxima.direct.io.blob.BlobStorageAccessor
Minimal size of partition in bytes.
Partition.IntegerPartition - Class in cz.o2.proxima.core.storage
 
PartitionedWatermarkEstimator - Interface in cz.o2.proxima.core.time
Watermark estimator wrapper for partitioned sources.
Partitioner - Interface in cz.o2.proxima.core.storage.commitlog
An interface that each class configured in KafkaCommitLog.PARTITIONER_CLASS must implement.
PARTITIONER - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
PARTITIONER_CLASS - Static variable in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
Partitioner class for entity key-attribute pair.
Partitioners - Class in cz.o2.proxima.core.storage.commitlog
Helper methods for partitioners.
partitions() - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogObserver.OnRepartitionContext
Retrieve list of currently assigned partitions.
PassthroughFilter - Class in cz.o2.proxima.core.storage
A StorageFilter passing in all values.
PassthroughFilter() - Constructor for class cz.o2.proxima.core.storage.PassthroughFilter
 
Path - Interface in cz.o2.proxima.direct.io.bulkfs
Proxima's abstraction of path in FileSystem.
PCollectionTools - Class in cz.o2.proxima.beam.core
Various tools related to manipulation with PCollections.
percentile(String, String, long, long) - Method in class cz.o2.proxima.core.metrics.MetricFactory
Construct the metric.
periodicImpulse(Closure<T>, long) - Method in interface cz.o2.proxima.tools.groovy.StreamProvider
Create new WindowedStream that contains single element per fixed time windowed.
periodicImpulse(String, Closure<T>, long) - Method in class cz.o2.proxima.beam.tools.groovy.BeamStreamProvider
 
periodicImpulse(String, Closure<T>, long) - Method in interface cz.o2.proxima.tools.groovy.StreamProvider
Create new WindowedStream that contains single element per fixed time windowed.
persist(RepositoryProvider, EntityDescriptor, Closure<CharSequence>, Closure<CharSequence>, Closure<V>, Closure<Long>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Persist this stream as attribute of entity
persistIntoTargetFamily(RepositoryProvider, String) - Method in interface cz.o2.proxima.tools.groovy.Stream
Persist this stream to specific family.
persistIntoTargetFamily(RepositoryProvider, String, int) - Method in interface cz.o2.proxima.tools.groovy.Stream
Persist this stream to specific family.
persistIntoTargetReplica(RepositoryProvider, String, String) - Method in interface cz.o2.proxima.tools.groovy.Stream
Persist this stream to replication.
Placeholder - Class in cz.o2.proxima.direct.io.hbase
Force creation of -sources and -javadoc jars
Placeholder - Class in cz.o2.proxima.direct.io.hdfs
Force creation of -sources and -javadoc jars
Placeholder - Class in cz.o2.proxima.generator.cli
Force creation of -sources and -javadoc jars
Placeholder - Class in cz.o2.proxima.scheme.proto.testing
Force creation of -sources and -javadoc jars
Placeholder() - Constructor for class cz.o2.proxima.direct.io.hbase.Placeholder
 
Placeholder() - Constructor for class cz.o2.proxima.direct.io.hdfs.Placeholder
 
Placeholder() - Constructor for class cz.o2.proxima.generator.cli.Placeholder
 
Placeholder() - Constructor for class cz.o2.proxima.scheme.proto.testing.Placeholder
 
POLL_INTERVAL_CFG - Static variable in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
A poll interval in milliseconds.
Position - Enum in cz.o2.proxima.core.storage.commitlog
An enum specifying the position in the commit log to start reading from.
prefixed(String, NamingConvention) - Static method in interface cz.o2.proxima.direct.io.bulkfs.NamingConvention
Create a NamingConvention that adds prefix to each generated name of parent convention.
prefixedKey(String) - Static method in class cz.o2.proxima.direct.core.time.WatermarkConfiguration
Returns configuration key with added watermark config prefix.
prefixesOf(long, long) - Method in class cz.o2.proxima.direct.io.bulkfs.DefaultNamingConvention
 
prefixesOf(long, long) - Method in interface cz.o2.proxima.direct.io.bulkfs.NamingConvention
Convert given time range to prefixes, at least one of which must all Paths in given time range have.
prepareForWrite(RecordConsumer) - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementWriteSupport
 
PRIMARY - cz.o2.proxima.core.storage.StorageType
A storage where each write is persisted at first.
PRIMITIVE - cz.o2.proxima.core.scheme.AttributeValueAccessor.Type
 
primitives(AttributeValueType) - Static method in class cz.o2.proxima.core.scheme.SchemaDescriptors
PrimitiveTypeDescriptor(AttributeValueType) - Constructor for class cz.o2.proxima.core.scheme.SchemaDescriptors.PrimitiveTypeDescriptor
 
PrimitiveValueAccessorImpl(UnaryFunction<T, V>, UnaryFunction<V, T>) - Constructor for class cz.o2.proxima.core.scheme.AttributeValueAccessors.PrimitiveValueAccessorImpl
 
print() - Method in interface cz.o2.proxima.tools.groovy.Stream
Print all elements to console.
processElement(T, DoFn.OutputReceiver<T>) - Method in class cz.o2.proxima.beam.core.transforms.BufferUntilCheckpoint
 
processingTime() - Static method in interface cz.o2.proxima.core.functional.TimeProvider
 
ProcessingTimeShiftingWatermarkIdlePolicy - Class in cz.o2.proxima.direct.core.time
Idle policy that shifts watermark by the amount of processing time elapsed in the idle state.
ProcessingTimeShiftingWatermarkIdlePolicy() - Constructor for class cz.o2.proxima.direct.core.time.ProcessingTimeShiftingWatermarkIdlePolicy
 
ProcessingTimeShiftingWatermarkIdlePolicy(Factory<Long>) - Constructor for class cz.o2.proxima.direct.core.time.ProcessingTimeShiftingWatermarkIdlePolicy
 
ProcessingTimeShiftingWatermarkIdlePolicy.Factory - Class in cz.o2.proxima.direct.core.time
 
ProcessingTimeWatermarkEstimator - Class in cz.o2.proxima.direct.core.time
Estimates watermark as processing time.
ProcessingTimeWatermarkEstimator.Builder - Class in cz.o2.proxima.direct.core.time
ProcessingTimeWatermarkEstimator.Factory - Class in cz.o2.proxima.direct.core.time
Creates an instance of ProcessingTimeWatermarkEstimator.
project - Variable in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubReader
 
ProtoMessageValueAccessor<T extends com.google.protobuf.Message> - Class in cz.o2.proxima.scheme.proto
Implementation of AttributeValueAccessors.StructureValueAccessor for ProtoBufs
ProtoMessageValueAccessor(Factory<T>) - Constructor for class cz.o2.proxima.scheme.proto.ProtoMessageValueAccessor
 
ProtoSerializerFactory - Class in cz.o2.proxima.scheme.proto
Serializer from protobuffers.
ProtoSerializerFactory() - Constructor for class cz.o2.proxima.scheme.proto.ProtoSerializerFactory
 
ProtoUtils - Class in cz.o2.proxima.scheme.proto.utils
 
ProximaIO - Class in cz.o2.proxima.beam.io
IO connector for Proxima platform.
ProximaIO.Write - Class in cz.o2.proxima.beam.io
Transformation that writes stream elements into proxima using DirectDataOperator.
ProximaParquetReader - Class in cz.o2.proxima.direct.io.bulkfs.parquet
 
ProximaParquetReader(Path, EntityDescriptor) - Constructor for class cz.o2.proxima.direct.io.bulkfs.parquet.ProximaParquetReader
 
ProximaParquetWriter - Class in cz.o2.proxima.direct.io.bulkfs.parquet
Writer for writing data in parquet format.
ProximaParquetWriter(Path, MessageType, String, CompressionCodecName, Configuration) - Constructor for class cz.o2.proxima.direct.io.bulkfs.parquet.ProximaParquetWriter
 
proxy - Variable in class cz.o2.proxima.core.repository.AttributeDescriptorBase
 
PROXY - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
ProxyTransform - Interface in cz.o2.proxima.core.transform
A transformation of attribute name applied both on reading and writing attribute.
PubSubAccessor - Class in cz.o2.proxima.direct.io.pubsub
A DataAccessor for Google PubSub.
PubSubBulkReader - Class in cz.o2.proxima.direct.io.pubsub
 
PubSubBulkReader(PubSubAccessor, Context) - Constructor for class cz.o2.proxima.direct.io.pubsub.PubSubBulkReader
 
PubSubDataAccessor - Class in cz.o2.proxima.beam.io.pubsub
A DataAccessor for PubSub.
PubSubDataAccessorFactory - Class in cz.o2.proxima.beam.io.pubsub
DataAccessorFactory for PubSub URLs.
PubSubDataAccessorFactory() - Constructor for class cz.o2.proxima.beam.io.pubsub.PubSubDataAccessorFactory
 
PubSubStorage - Class in cz.o2.proxima.direct.io.pubsub
A DataAccessorFactory for PubSub.
PubSubStorage() - Constructor for class cz.o2.proxima.direct.io.pubsub.PubSubStorage
 
PubSubUtils - Class in cz.o2.proxima.io.pubsub.util
 
PubSubWatermarkConfiguration - Class in cz.o2.proxima.direct.io.pubsub
Watermark configuration for PubSub
PubSubWatermarkConfiguration(Map<String, Object>, long, long) - Constructor for class cz.o2.proxima.direct.io.pubsub.PubSubWatermarkConfiguration
 
put(EntityDescriptor, AttributeDescriptor<?>, String, String, long, String) - Method in class cz.o2.proxima.tools.groovy.Console
 
put(EntityDescriptor, AttributeDescriptor<?>, String, String, String) - Method in class cz.o2.proxima.tools.groovy.Console
 
put(String, Object) - Method in class cz.o2.proxima.core.scheme.AttributeValueAccessors.StructureValueImpl
 
putAll(Map<? extends String, ?>) - Method in class cz.o2.proxima.core.scheme.AttributeValueAccessors.StructureValueImpl
 
putStream(Repository, AttributeFamilyDescriptor, TestStream<StreamElement>) - Static method in class cz.o2.proxima.beam.storage.TestStreamStorage
Put given TestStream for given AttributeFamilyDescriptor.

R

RANDOM_ACCESS - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
RandomAccessReader - Interface in cz.o2.proxima.direct.core.randomaccess
Reader of data stored in random access storage.
RandomAccessReader.Factory<T extends RandomAccessReader> - Interface in cz.o2.proxima.direct.core.randomaccess
Serializable factory for RandomAccessReader.
RandomAccessReader.GetRequest<T> - Class in cz.o2.proxima.direct.core.randomaccess
A wraper for a get request.
RandomAccessReader.Listing - Enum in cz.o2.proxima.direct.core.randomaccess
Type of listing (either listing entities of entity attributes).
RandomAccessReader.MultiFetch - Interface in cz.o2.proxima.direct.core.randomaccess
A facade for fetching multiple KeyValues in single request.
RandomHBaseReader - Class in cz.o2.proxima.direct.io.hbase
RandomAccessReader for HBase.
RandomHBaseReader(URI, Configuration, Map<String, Object>, EntityDescriptor) - Constructor for class cz.o2.proxima.direct.io.hbase.RandomHBaseReader
 
RandomOffset - Interface in cz.o2.proxima.direct.core.randomaccess
An interface representing offset for paging.
Raw(String) - Constructor for class cz.o2.proxima.direct.jdbc.Offsets.Raw
 
RawOffset - Class in cz.o2.proxima.direct.core.randomaccess
Offset that is represented by raw string.
RawOffset(String) - Constructor for class cz.o2.proxima.direct.core.randomaccess.RawOffset
 
read() - Method in interface cz.o2.proxima.direct.io.bulkfs.Path
Open readable byte channel from a given Path.
read() - Method in class cz.o2.proxima.direct.io.s3.S3BlobPath
 
read(Kryo, Input, Class<? extends GString>) - Method in class cz.o2.proxima.beam.tools.groovy.GStringSerializer
 
read(Kryo, Input, Class<? extends Tuple<Object>>) - Method in class cz.o2.proxima.beam.tools.groovy.TupleSerializer
 
read(ConsumerRecord<byte[], byte[]>, EntityDescriptor) - Method in class cz.o2.proxima.direct.io.kafka.serializer.ValueAsBytesSerializer
 
read(ConsumerRecord<String, byte[]>, EntityDescriptor) - Method in class cz.o2.proxima.direct.io.kafka.KafkaStreamElement.KafkaStreamElementSerializer
 
read(ConsumerRecord<Void, String>, EntityDescriptor) - Method in class cz.o2.proxima.direct.io.kafka.serializer.ValueAsStringSerializer
 
read(ConsumerRecord<K, V>, EntityDescriptor) - Method in interface cz.o2.proxima.direct.io.kafka.ElementSerializer
Parse the raw bytes from Kafka and return a StreamElement.
READ - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
READ_ONLY - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
reader() - Method in class cz.o2.proxima.direct.io.blob.BlobPath
 
reader() - Method in class cz.o2.proxima.direct.io.bulkfs.LocalPath
 
reader() - Method in interface cz.o2.proxima.direct.io.bulkfs.Path
Deprecated.
Use Path.read() instead.
reader() - Method in class cz.o2.proxima.direct.io.gcloud.storage.GCloudBlobPath
 
reader() - Method in class cz.o2.proxima.direct.io.s3.S3BlobPath
 
Reader - Interface in cz.o2.proxima.direct.io.bulkfs
Proxima's representation of generic reader.
readingPartition(Partition, Position, long, boolean) - Static method in class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker.OffsetRange
 
readResolve() - Method in class cz.o2.proxima.core.storage.watermark.GlobalWatermarkThroughputLimiter
 
readResolve() - Method in class cz.o2.proxima.core.utils.zookeeper.ZKGlobalWatermarkTracker
 
record - Variable in class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementMaterializer.ParquetColumnRecordConverter
 
reduce(Closure<K>, Closure<V>, V, Closure<V>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Reduce stream via given reducer.
reduce(Closure<K>, V, Closure<V>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Reduce stream via given reducer.
reduce(String, Closure<K>, Closure<V>, V, Closure<V>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Reduce stream via given reducer.
reduce(String, Closure<K>, V, Closure<V>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Reduce stream via given reducer.
reduceAsSnapshot(String, PCollection<StreamElement>) - Static method in class cz.o2.proxima.beam.core.PCollectionTools
Reduce given PCollection from updates to snapshot.
reduceToLatest() - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Reduce stream to latest values only.
reduceToLatest(String) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Reduce stream to latest values only.
reduceValueStateByKey(Closure<K>, Closure<V>, Closure<S>, Closure<O>, Closure<S>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Transform this stream using stateful processing.
reduceValueStateByKey(String, Closure<K>, Closure<V>, Closure<S>, Closure<O>, Closure<S>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Transform this stream using stateful processing.
reduceValueStateByKey(String, Closure<K>, Closure<V>, Closure<S>, Closure<O>, Closure<S>, boolean) - Method in interface cz.o2.proxima.tools.groovy.Stream
Transform this stream using stateful processing.
reduceValueStateByKeyUnsorted(Closure<K>, Closure<V>, Closure<S>, Closure<O>, Closure<S>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Transform this stream using stateful processing without time-sorting.
reduceValueStateByKeyUnsorted(String, Closure<K>, Closure<V>, Closure<S>, Closure<O>, Closure<S>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Transform this stream using stateful processing without time-sorting.
register(Metric<?>) - Method in class cz.o2.proxima.core.metrics.JmxMetricsRegistrar
 
register(Metric<?>) - Method in interface cz.o2.proxima.core.metrics.MetricsRegistrar
 
register(ID, long, int, OffsetCommitter.Callback) - Method in class cz.o2.proxima.direct.io.kafka.OffsetCommitter
Register number of actions to be performed before offset can be committed.
registerToPipeline(PipelineOptions, String, Collection<File>) - Static method in class cz.o2.proxima.beam.util.RunnerUtils
Register given set of jars to runner.
registerWithMBeanServer(Metric<?>) - Method in class cz.o2.proxima.core.metrics.JmxMetricsRegistrar
Register this metric with MBeanServer.
REJECT - cz.o2.proxima.core.storage.internal.AbstractDataAccessorFactory.Accept
The URI is rejected and cannot be handled by this factory.
release(String) - Method in interface cz.o2.proxima.direct.core.transaction.ClientTransactionManager
Release resources associated with given transaction.
release(String) - Method in class cz.o2.proxima.direct.core.transaction.TransactionResourceManager
 
releaseDataSource() - Method in class cz.o2.proxima.direct.jdbc.JdbcDataAccessor
 
reload() - Method in class cz.o2.proxima.beam.core.BeamDataOperator
 
reload() - Method in interface cz.o2.proxima.core.repository.DataOperator
Reload the operator after Repository has been changed.
reload() - Method in class cz.o2.proxima.direct.core.DirectDataOperator
 
reloadConfig(boolean, Config) - Method in class cz.o2.proxima.core.repository.ConfigRepository
 
remove(Object) - Method in class cz.o2.proxima.core.scheme.AttributeValueAccessors.StructureValueImpl
 
RenameTransformation - Class in cz.o2.proxima.core.transform
A stateless transformation that performs transformation from one attribute to another.
RenameTransformation() - Constructor for class cz.o2.proxima.core.transform.RenameTransformation
 
RenameTransformation(UnaryFunction<AttributeDescriptor<?>, AttributeDescriptor<?>>, BiFunction<String, AttributeDescriptor<?>, String>) - Constructor for class cz.o2.proxima.core.transform.RenameTransformation
 
renaming(String, String) - Static method in interface cz.o2.proxima.core.transform.ElementWiseProxyTransform
Proxy renaming attribute.
replaceStorages(Config) - Static method in class cz.o2.proxima.beam.storage.TestStreamStorage
Replace all storages in all attribute families in given config with test-stream.
replaceStorages(Config, UnaryPredicate<String>) - Static method in class cz.o2.proxima.beam.storage.TestStreamStorage
Replace all storages in all attribute families in given config with test-stream.
replica - Variable in class cz.o2.proxima.core.repository.AttributeDescriptorBase
 
REPLICA - cz.o2.proxima.core.storage.StorageType
A storage where each write is replicated from commit storage.
ReplicationController - Class in cz.o2.proxima.direct.server
Server that controls replications of primary commit logs to replica attribute families.
REPLICATIONS - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
reportConsumed() - Method in class cz.o2.proxima.beam.core.direct.io.BatchRestrictionTracker.PartitionList
 
reportConsumerWatermark(String, boolean, long, long) - Static method in class cz.o2.proxima.direct.server.metrics.Metrics
 
reportConsumerWatermark(String, long, long) - Method in class cz.o2.proxima.direct.core.transform.TransformationObserver
 
Repository - Class in cz.o2.proxima.core.repository
Repository of all entities configured in the system.
Repository.Validate - Enum in cz.o2.proxima.core.repository
Various validation flags.
RepositoryFactory - Interface in cz.o2.proxima.core.repository
Factory for Repository.
RepositoryFactory.Compressed - Class in cz.o2.proxima.core.repository
 
RepositoryFactory.LocalInstance - Class in cz.o2.proxima.core.repository
 
RepositoryFactory.VersionedCaching - Class in cz.o2.proxima.core.repository
 
RepositoryProvider - Interface in cz.o2.proxima.tools.groovy
Provider of repository.
Request - Class in cz.o2.proxima.core.transaction
A transactional request sent to coordinator.
Request() - Constructor for class cz.o2.proxima.core.transaction.Request
 
Request(List<KeyAttribute>, Collection<StreamElement>, Request.Flags, int) - Constructor for class cz.o2.proxima.core.transaction.Request
 
REQUEST_ATTRIBUTE - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
Request.Flags - Enum in cz.o2.proxima.core.transaction
 
reset() - Method in class cz.o2.proxima.core.metrics.AbsoluteMetric
 
reset() - Method in class cz.o2.proxima.core.metrics.ApproxPercentileMetric
 
reset() - Method in class cz.o2.proxima.core.metrics.GaugeMetric
 
reset() - Method in class cz.o2.proxima.core.metrics.Metric
Reset the metric to initial state.
reset() - Method in class cz.o2.proxima.core.metrics.TimeAveragingMetric
 
reset(C) - Method in class cz.o2.proxima.core.util.SerializableScopedValue
Clear reference for given context and reinitialize it when accessed again.
resetOffsets(List<Offset>) - Method in interface cz.o2.proxima.direct.core.commitlog.ObserveHandle
Reset the consumption to given offsets.
reshuffle() - Method in interface cz.o2.proxima.tools.groovy.Stream
Reshuffle the stream via random key.
reshuffle(String) - Method in interface cz.o2.proxima.tools.groovy.Stream
Reshuffle the stream via random key.
resolve(AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.core.Context
resolve(AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.core.DirectDataOperator
Optionally convert given family to direct representation.
resolveRequired(AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.core.Context
 
resolveRequired(AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.core.DirectDataOperator
Convert given core family to direct representation.
Response - Class in cz.o2.proxima.core.transaction
 
Response() - Constructor for class cz.o2.proxima.core.transaction.Response
 
Response(Response.Flags, long, long, int) - Constructor for class cz.o2.proxima.core.transaction.Response
 
RESPONSE_ATTRIBUTE - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
RESPONSE_ATTRIBUTE_PREFIX - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
Response.Flags - Enum in cz.o2.proxima.core.transaction
 
restoresSequentialIds() - Method in interface cz.o2.proxima.direct.core.commitlog.CommitLogReader
Signals the user that this CommitLogReader is able to recover sequential IDs sent to it in StreamElements through its associated writer.
restoresSequentialIds() - Method in class cz.o2.proxima.direct.io.kafka.KafkaLogReader
 
ResultExtractor<T> - Interface in cz.o2.proxima.flink.core
Simple function, that extracts StreamElement into a desired type.
RETHROW - cz.o2.proxima.direct.core.commitlog.CommitLogObservers.TerminationStrategy
Exception is rethrown an handled by exception handler.
rethrowAsIllegalStateException(Throwable) - Static method in class cz.o2.proxima.core.util.ExceptionUtils
Throw an IllegalStateException with given exception as cause.
RetrieveService - Class in cz.o2.proxima.direct.server
Service for reading data.
RetrieveService(Repository, DirectDataOperator, TransactionContext) - Constructor for class cz.o2.proxima.direct.server.RetrieveService
 
retry(Factory<T>) - Method in class cz.o2.proxima.direct.io.blob.RetryStrategy
 
retry(Runnable) - Method in class cz.o2.proxima.direct.io.blob.RetryStrategy
 
RetryStrategy - Class in cz.o2.proxima.direct.io.blob
 
RetryStrategy(int, int) - Constructor for class cz.o2.proxima.direct.io.blob.RetryStrategy
 
returnClass(Closure<T>) - Static method in class cz.o2.proxima.tools.groovy.util.Types
Retrieve class object of return type of given Closure.
rollback() - Method in interface cz.o2.proxima.direct.core.AttributeWriterBase
Rollback the writer to last committed position.
rollback() - Method in interface cz.o2.proxima.direct.core.OnlineAttributeWriter
 
rollback() - Method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.Transaction
 
rollback() - Method in class cz.o2.proxima.direct.io.blob.BulkBlobWriter
 
rollback() - Method in class cz.o2.proxima.direct.io.bulkfs.AbstractBulkFileSystemAttributeWriter
 
rollback() - Method in class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchWriter
 
rollback() - Method in interface cz.o2.proxima.direct.server.transaction.TransactionContext.Transaction
 
rollback(String) - Method in interface cz.o2.proxima.direct.core.transaction.ClientTransactionManager
Rollback transaction with given ID.
rollback(String) - Method in class cz.o2.proxima.direct.core.transaction.TransactionResourceManager
 
ROLLBACK - cz.o2.proxima.core.transaction.Request.Flags
 
RowAsJsonConverter - Class in cz.o2.proxima.direct.jdbc
 
RowAsJsonConverter() - Constructor for class cz.o2.proxima.direct.jdbc.RowAsJsonConverter
 
RowAsJsonLogReaderStatementFactory - Class in cz.o2.proxima.direct.jdbc
 
RowAsJsonLogReaderStatementFactory() - Constructor for class cz.o2.proxima.direct.jdbc.RowAsJsonLogReaderStatementFactory
 
rpcGet(EntityDescriptor, String, String, String, int) - Method in class cz.o2.proxima.tools.groovy.Console
 
rpcList(EntityDescriptor, String, AttributeDescriptor<?>, String, int, String, int) - Method in class cz.o2.proxima.tools.groovy.Console
 
run() - Method in interface cz.o2.proxima.core.util.ExceptionUtils.ThrowingRunnable
 
run() - Method in interface cz.o2.proxima.direct.io.blob.BlobLogReader.ThrowingRunnable
 
run() - Method in class cz.o2.proxima.direct.server.IngestServer
Run the server.
run() - Method in class cz.o2.proxima.direct.server.transaction.TransactionContext
 
run() - Method in class cz.o2.proxima.direct.transaction.manager.TransactionManagerServer
 
run() - Method in class cz.o2.proxima.tools.groovy.Compiler
 
run(String) - Method in class cz.o2.proxima.direct.transaction.manager.TransactionLogObserver
 
runHandlingErrors(BlobT, BlobLogReader.ThrowingRunnable) - Method in class cz.o2.proxima.direct.io.blob.BlobLogReader
 
runHandlingErrors(GCloudBlobPath.GCloudBlob, BlobLogReader.ThrowingRunnable) - Method in class cz.o2.proxima.direct.io.gcloud.storage.GCloudLogReader
 
runHandlingErrors(S3BlobPath.S3Blob, BlobLogReader.ThrowingRunnable) - Method in class cz.o2.proxima.direct.io.s3.S3LogReader
 
RunnerUtils - Class in cz.o2.proxima.beam.util
 
runObservations(String, BiConsumer<StreamElement, Pair<Long, Object>>, CommitLogObserver) - Method in interface cz.o2.proxima.direct.core.transaction.ServerTransactionManager
Observe all transactional families with given observer.
runObservations(String, BiConsumer<StreamElement, Pair<Long, Object>>, CommitLogObserver) - Method in class cz.o2.proxima.direct.core.transaction.TransactionResourceManager
Observe all transactional families with given observer.
runReplicationThreads() - Method in class cz.o2.proxima.direct.server.ReplicationController
 
runWithServerFactory(Factory<? extends IngestServer>) - Static method in class cz.o2.proxima.direct.server.IngestServer
 

S

S3BlobPath - Class in cz.o2.proxima.direct.io.s3
A Path representation of a remote blob in S3.
S3BlobPath.S3Blob - Class in cz.o2.proxima.direct.io.s3
 
S3FileSystem - Class in cz.o2.proxima.direct.io.s3
FileSystem implementation for gs://.
S3LogReader - Class in cz.o2.proxima.direct.io.s3
BatchLogReader for gcloud storage.
S3LogReader(S3Accessor, Context) - Constructor for class cz.o2.proxima.direct.io.s3.S3LogReader
 
S3StorageDescriptor - Class in cz.o2.proxima.direct.io.s3
A DataAccessorFactory for gcloud storage.
S3StorageDescriptor() - Constructor for class cz.o2.proxima.direct.io.s3.S3StorageDescriptor
 
ScalarMetric - Class in cz.o2.proxima.core.metrics
A metric with single scalar value.
ScalarMetric(String, String) - Constructor for class cz.o2.proxima.core.metrics.ScalarMetric
 
ScalarMetricMBean<T> - Interface in cz.o2.proxima.core.metrics
A bean representing a metric.
scan(Rpc.ScanRequest, StreamObserver<Rpc.ScanResult>) - Method in class cz.o2.proxima.direct.server.RetrieveService
 
scanAll(HikariDataSource) - Method in class cz.o2.proxima.direct.jdbc.RowAsJsonLogReaderStatementFactory
 
scanAll(HikariDataSource) - Method in interface cz.o2.proxima.direct.jdbc.SqlStatementFactory
Scan the complete content of table.
scanAttributes(String, List<String>, Consumer<Rpc.ScanResult>) - Method in class cz.o2.proxima.direct.client.IngestClient
Scan through attributes of an entity
scanPartition(List<AttributeDescriptor<?>>, CassandraPartition, Session) - Method in interface cz.o2.proxima.direct.io.cassandra.CqlFactory
Retrieve a bound statement to scan data for given attribute and partition.
scanPartition(List<AttributeDescriptor<?>>, CassandraPartition, Session) - Method in class cz.o2.proxima.direct.io.cassandra.DefaultCqlFactory
 
scanPartition(List<AttributeDescriptor<?>>, CassandraPartition, Session) - Method in class cz.o2.proxima.direct.io.cassandra.TransformingCqlFactory
 
scanWildcard(String, AttributeDescriptor<T>, long, Consumer<KeyValue<T>>) - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
List data stored for a particular wildcard attribute.
scanWildcard(String, AttributeDescriptor<T>, Consumer<KeyValue<T>>) - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
List data stored for a particular wildcard attribute.
scanWildcard(String, AttributeDescriptor<T>, RandomOffset, int, Consumer<KeyValue<T>>) - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
List data stored for a particular wildcard attribute.
scanWildcard(String, AttributeDescriptor<T>, RandomOffset, long, int, Consumer<KeyValue<T>>) - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
List data stored for a particular wildcard attribute.
scanWildcard(String, AttributeDescriptor<T>, RandomOffset, long, int, Consumer<KeyValue<T>>) - Method in class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
scanWildcard(String, AttributeDescriptor<T>, RandomOffset, long, int, Consumer<KeyValue<T>>) - Method in class cz.o2.proxima.direct.io.hbase.RandomHBaseReader
 
scanWildcard(String, AttributeDescriptor<T>, RandomOffset, long, int, Consumer<KeyValue<T>>) - Method in class cz.o2.proxima.direct.jdbc.JdbcOnlineAttributeReader
 
scanWildcardAll(String, long, Consumer<KeyValue<?>>) - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
Scan all data stored per given key.
scanWildcardAll(String, Consumer<KeyValue<?>>) - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
Scan all data stored per given key.
scanWildcardAll(String, RandomOffset, int, Consumer<KeyValue<?>>) - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
Scan all data stored per given key.
scanWildcardAll(String, RandomOffset, long, int, Consumer<KeyValue<?>>) - Method in interface cz.o2.proxima.direct.core.randomaccess.RandomAccessReader
Scan all data stored per given key.
scanWildcardAll(String, RandomOffset, long, int, Consumer<KeyValue<?>>) - Method in class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
scanWildcardAll(String, RandomOffset, long, int, Consumer<KeyValue<?>>) - Method in class cz.o2.proxima.direct.io.hbase.RandomHBaseReader
 
scanWildcardAll(String, RandomOffset, long, int, Consumer<KeyValue<?>>) - Method in class cz.o2.proxima.direct.jdbc.JdbcOnlineAttributeReader
 
SchemaDescriptors - Class in cz.o2.proxima.core.scheme
SchemaDescriptors for types.
SchemaDescriptors.ArrayTypeDescriptor<T> - Class in cz.o2.proxima.core.scheme
Array type descriptor allows to use other descriptor as value.
SchemaDescriptors.EnumTypeDescriptor<T> - Class in cz.o2.proxima.core.scheme
Enum type descriptor.
SchemaDescriptors.PrimitiveTypeDescriptor<T> - Class in cz.o2.proxima.core.scheme
Primitive type descriptor with simple type (eq String, Long, Integer, etc).
SchemaDescriptors.SchemaTypeDescriptor<T> - Interface in cz.o2.proxima.core.scheme
Generic type descriptor.
SchemaDescriptors.StructureTypeDescriptor<T> - Class in cz.o2.proxima.core.scheme
Structure type descriptor allows to have fields with type as another descriptor.
SchemaRegistrySerializerFactory - Class in cz.o2.proxima.scheme.confluent
 
SchemaRegistrySerializerFactory() - Constructor for class cz.o2.proxima.scheme.confluent.SchemaRegistrySerializerFactory
 
SchemaStreamElementCoder - Class in cz.o2.proxima.beam.core.io
 
SCHEME - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
SCHEME_PROVIDER - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
schemeUri - Variable in class cz.o2.proxima.core.repository.AttributeDescriptorBase
 
send(Rpc.Ingest, long, TimeUnit, Consumer<Rpc.Status>) - Method in class cz.o2.proxima.direct.client.IngestClient
Send the request with timeout.
send(Rpc.Ingest, Consumer<Rpc.Status>) - Method in class cz.o2.proxima.direct.client.IngestClient
Send the request.
SEQUENCE_ID_HEADER - Static variable in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
A name for a header containing sequential ID of StreamElement (if any).
SerializableAbstractStorage() - Constructor for class cz.o2.proxima.core.storage.AbstractStorage.SerializableAbstractStorage
 
SerializableAbstractStorage(EntityDescriptor, URI) - Constructor for class cz.o2.proxima.core.storage.AbstractStorage.SerializableAbstractStorage
 
SerializableScopedValue<C,​V> - Class in cz.o2.proxima.core.util
A value that holds a Serializable value and scopes its value to given context.
SerializableScopedValue(C, V) - Constructor for class cz.o2.proxima.core.util.SerializableScopedValue
 
SerializableScopedValue(Factory<V>) - Constructor for class cz.o2.proxima.core.util.SerializableScopedValue
 
SerializableUtils - Class in cz.o2.proxima.core.util
Various serialization related utilities.
SerializationException - Exception in cz.o2.proxima.core.scheme
 
SerializationException(String) - Constructor for exception cz.o2.proxima.core.scheme.SerializationException
 
SerializationException(String, Throwable) - Constructor for exception cz.o2.proxima.core.scheme.SerializationException
 
serialize(T) - Method in interface cz.o2.proxima.core.scheme.ValueSerializer
Serialize value to bytes.
serialize(T) - Method in class cz.o2.proxima.scheme.avro.AvroSerializer
 
serialize(T, ByteArrayOutputStream) - Method in class cz.o2.proxima.scheme.avro.AvroSerializer
 
SERIALIZER_CLASS - Static variable in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
Class performing parsing from (String, byte[]) to StreamElement.
SERIALIZERS - cz.o2.proxima.core.repository.Repository.Validate
Validate scheme serializers.
ServerTransactionManager - Interface in cz.o2.proxima.direct.core.transaction
 
ServerTransactionManager.InitialSequenceIdPolicy - Interface in cz.o2.proxima.direct.core.transaction
 
ServerTransactionManager.InitialSequenceIdPolicy.Default - Class in cz.o2.proxima.direct.core.transaction
 
ServerTransactionManager.ServerTransactionConfig - Interface in cz.o2.proxima.direct.core.transaction
 
sessionWindow(Closure<K>, long) - Method in interface cz.o2.proxima.tools.groovy.Stream
Create session windowed stream.
setLayer(ModuleLayer) - Method in class cz.o2.proxima.core.util.internal.ClassLoaders.ChildLayerFirstClassLoader
 
setMinWatermark(long) - Method in interface cz.o2.proxima.core.time.WatermarkEstimator
Sets minimal watermark to ensuring that the watermark won't move back for already committed watermark
setMinWatermark(long) - Method in class cz.o2.proxima.direct.core.time.BoundedOutOfOrdernessWatermarkEstimator
 
setMinWatermark(long) - Method in class cz.o2.proxima.direct.core.time.ProcessingTimeWatermarkEstimator
 
setMinWatermark(long) - Method in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator
 
setParsed(Object) - Method in class cz.o2.proxima.core.storage.StreamElement
 
setRepository(Repository) - Method in interface cz.o2.proxima.core.scheme.ValueSerializer.InitializedWithRepository
 
setStartBatchReadDelayMs(long) - Method in interface cz.o2.proxima.beam.core.direct.io.BatchLogRead.BatchLogReadPipelineOptions
 
setTransaction(TransactionalOnlineAttributeWriter.Transaction) - Method in interface cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.TransactionAware
 
setTransaction(TransactionalOnlineAttributeWriter.Transaction) - Method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.TransactionValidator
 
setTransactionTimeoutMs(long) - Method in class cz.o2.proxima.direct.core.transaction.TransactionResourceManager
 
setTransforms(UnaryFunction<AttributeDescriptor<?>, AttributeDescriptor<?>>, BiFunction<String, AttributeDescriptor<?>, String>) - Method in class cz.o2.proxima.core.transform.RenameTransformation
Update desc and name transforms.
setup() - Method in interface cz.o2.proxima.direct.jdbc.Converter
 
setup(AttributeDescriptor<?>) - Method in interface cz.o2.proxima.core.transform.ElementWiseProxyTransform
setup(AttributeFamilyDescriptor) - Method in interface cz.o2.proxima.direct.io.bulkfs.FileFormat
Setup FileFormat for given AttributeFamilyDescriptor.
setup(AttributeFamilyDescriptor) - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.ParquetFileFormat
 
setup(EntityDescriptor) - Method in interface cz.o2.proxima.direct.io.kafka.ElementSerializer
Life-cycle method called after being instantiated to be able to parameterize itself from the given EntityDescriptor.
setup(EntityDescriptor) - Method in class cz.o2.proxima.direct.io.kafka.serializer.ValueAsBytesSerializer
 
setup(EntityDescriptor) - Method in class cz.o2.proxima.direct.io.kafka.serializer.ValueAsStringSerializer
 
setup(EntityDescriptor, URI, StringConverter<?>) - Method in class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
 
setup(EntityDescriptor, URI, StringConverter<?>) - Method in interface cz.o2.proxima.direct.io.cassandra.CqlFactory
Setup the factory from URI and given string converter.
setup(EntityDescriptor, URI, Map<String, Object>, HikariDataSource) - Method in class cz.o2.proxima.direct.jdbc.RowAsJsonLogReaderStatementFactory
 
setup(EntityDescriptor, URI, Map<String, Object>, HikariDataSource) - Method in interface cz.o2.proxima.direct.jdbc.SqlStatementFactory
 
setup(EntityDescriptor, OP) - Method in interface cz.o2.proxima.core.transform.ContextualProxyTransform
Setup this transform for given entity.
setup(Repository) - Method in class cz.o2.proxima.beam.core.direct.io.DirectDataAccessorFactory
 
setup(Repository) - Method in class cz.o2.proxima.beam.storage.TestStreamStorage
 
setup(Repository) - Method in interface cz.o2.proxima.core.storage.internal.AbstractDataAccessorFactory
Setup the factory for using given Repository.
setup(Repository) - Method in class cz.o2.proxima.direct.core.DirectDataOperator.DelegateDataAccessorFactory
 
setup(Repository) - Method in class cz.o2.proxima.direct.io.pubsub.PubSubStorage
 
setup(Repository, DirectDataOperator, Map<String, Object>) - Method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.TransactionValidator
 
setup(Repository, DirectDataOperator, Map<String, Object>) - Method in class cz.o2.proxima.direct.core.transaction.TransactionCommitTransformation
 
setup(Repository, DirectDataOperator, Map<String, Object>) - Method in interface cz.o2.proxima.direct.core.transform.DirectElementWiseTransform
 
setup(Repository, Map<String, Object>) - Method in interface cz.o2.proxima.core.storage.StorageFilter
Setup filter
setup(Repository, Map<String, Object>) - Method in interface cz.o2.proxima.core.transform.ElementWiseTransformation
Setup this transform.
setup(Repository, Map<String, Object>) - Method in class cz.o2.proxima.core.transform.IdentityTransformation
 
setup(Repository, Map<String, Object>) - Method in class cz.o2.proxima.core.transform.RenameTransformation
 
setup(Repository, OP, Map<String, Object>) - Method in interface cz.o2.proxima.core.transform.ContextualTransformation
Read the repository and setup descriptors of target entity and attributes.
setup(ElementWiseProxyTransform.ProxySetupContext) - Method in interface cz.o2.proxima.core.transform.ElementWiseProxyTransform
Setup this transform with specified target and source attribute.
setup(Map<String, ?>) - Method in interface cz.o2.proxima.core.storage.commitlog.Partitioner
Setup the partitioner (if needed).
setup(Map<String, Object>) - Method in interface cz.o2.proxima.core.storage.ThroughputLimiter
Setup the limiter with given configuration.
setup(Map<String, Object>) - Method in class cz.o2.proxima.core.storage.watermark.GlobalWatermarkThroughputLimiter
 
setup(Map<String, Object>) - Method in interface cz.o2.proxima.core.storage.watermark.GlobalWatermarkTracker
Configure the tracker using given configuration.
setup(Map<String, Object>) - Method in interface cz.o2.proxima.core.time.WatermarkIdlePolicyFactory
Configure the factory based on the provided configuration.
setup(Map<String, Object>) - Method in class cz.o2.proxima.core.utils.zookeeper.ZKGlobalWatermarkTracker
 
setup(Map<String, Object>) - Method in class cz.o2.proxima.direct.core.time.NotProgressingWatermarkIdlePolicy.Factory
 
setup(Map<String, Object>) - Method in class cz.o2.proxima.direct.core.time.ProcessingTimeShiftingWatermarkIdlePolicy.Factory
 
setup(Map<String, Object>) - Method in class cz.o2.proxima.direct.core.time.SkewedProcessingTimeIdlePolicy.Factory
 
setup(Map<String, Object>) - Method in class cz.o2.proxima.flink.utils.FlinkGlobalWatermarkTracker
 
setup(Map<String, Object>, WatermarkIdlePolicyFactory) - Method in interface cz.o2.proxima.core.time.WatermarkEstimatorFactory
Configure the estimator factory based on provided configuration.
setup(Map<String, Object>, WatermarkIdlePolicyFactory) - Method in class cz.o2.proxima.direct.core.time.BoundedOutOfOrdernessWatermarkEstimator.Factory
 
setup(Map<String, Object>, WatermarkIdlePolicyFactory) - Method in class cz.o2.proxima.direct.core.time.ProcessingTimeWatermarkEstimator.Factory
 
setup(Map<String, Object>, WatermarkIdlePolicyFactory) - Method in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator.Factory
 
setup(Map<String, String>, StringConverter<?>) - Method in class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
Setup the factory from URI parameters passed in.
setup(Map<String, String>, StringConverter<?>) - Method in class cz.o2.proxima.direct.io.cassandra.DefaultCqlFactory
 
setup(T) - Method in interface cz.o2.proxima.core.repository.ConsumerNameFactory
Initialize for given context.
setValue(double) - Method in class cz.o2.proxima.core.metrics.AbsoluteMetric
 
shouldReportRejected(String, State) - Method in interface cz.o2.proxima.direct.core.transaction.TransactionMonitoringPolicy
Called when transaction is about to be aborted.
SimpleOffset() - Constructor for class cz.o2.proxima.direct.core.batch.Offset.SimpleOffset
 
size() - Method in class cz.o2.proxima.core.scheme.AttributeValueAccessors.StructureValueImpl
 
size() - Method in interface cz.o2.proxima.core.storage.Partition
Estimate size of this partition.
size() - Method in class cz.o2.proxima.direct.core.batch.BoundedPartition
 
size() - Method in class cz.o2.proxima.direct.io.hadoop.HadoopPartition
 
sizeForAttribute(AttributeDescriptor<?>) - Static method in class cz.o2.proxima.direct.server.metrics.Metrics
 
SkewedProcessingTimeIdlePolicy - Class in cz.o2.proxima.direct.core.time
Policy returns skewed (delayed) processing time when source is idle.
SkewedProcessingTimeIdlePolicy.Factory - Class in cz.o2.proxima.direct.core.time
 
sorted() - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Sort stream consisting of Comparables.
sorted(Closure<Integer>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Sort stream.
sorted(String) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Sort stream consisting of Comparables.
sorted(String, Closure<Integer>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Sort stream.
SOURCE - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
SPACE_AND_DASH - cz.o2.proxima.core.util.CamelCase.Characters
 
SPACE_DASH_AND_UNDERSCORE - cz.o2.proxima.core.util.CamelCase.Characters
 
split(int) - Method in interface cz.o2.proxima.core.storage.Partition
Split this partition to given number of sub-partitions.
split(int, PipelineOptions) - Method in class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource
 
SqlStatementFactory - Interface in cz.o2.proxima.direct.jdbc
 
Stable - Annotation Type in cz.o2.proxima.core.annotations
Annotation used on stable features.
start() - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementMaterializer.ParquetColumnListRecordConverter
 
start() - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementMaterializer.ParquetColumnRecordConverter
 
state(StateValue) - Static method in class cz.o2.proxima.beam.util.state.StateOrInput
 
State - Class in cz.o2.proxima.core.transaction
 
State() - Constructor for class cz.o2.proxima.core.transaction.State
 
STATE_ATTRIBUTE - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
STATE_COMMIT_LOG - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
State.Flags - Enum in cz.o2.proxima.core.transaction
 
StateOrInput<T> - Class in cz.o2.proxima.beam.util.state
 
StateOrInput() - Constructor for class cz.o2.proxima.beam.util.state.StateOrInput
 
StateOrInput.StateOrInputCoder<T> - Class in cz.o2.proxima.beam.util.state
 
stateUpdate(String, State, State) - Method in interface cz.o2.proxima.direct.core.transaction.TransactionMonitoringPolicy
Called when transaction state is about to be updated.
StateValue - Class in cz.o2.proxima.beam.util.state
 
StateValue() - Constructor for class cz.o2.proxima.beam.util.state.StateValue
 
StateValue.StateValueCoder - Class in cz.o2.proxima.beam.util.state
 
Stats - Class in cz.o2.proxima.core.metrics
Stats aggregating the distribution percentiles.
StatsMBean - Interface in cz.o2.proxima.core.metrics
An MBean for distribution stats.
stdin(FileFormat) - Static method in interface cz.o2.proxima.direct.io.bulkfs.Path
 
StdoutStorage - Class in cz.o2.proxima.direct.core
Dummy storage printing data to stdout.
StdoutStorage() - Constructor for class cz.o2.proxima.direct.core.StdoutStorage
 
STEP_MS - Static variable in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator
 
stop(boolean) - Method in class cz.o2.proxima.direct.transaction.manager.TransactionManagerServer
 
STOP_PROCESSING - cz.o2.proxima.direct.core.commitlog.CommitLogObservers.TerminationStrategy
Halt processing.
STORAGE - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
StorageFilter - Interface in cz.o2.proxima.core.storage
A filter that is applied to each input element.
StorageFilter.AndFilter - Class in cz.o2.proxima.core.storage
Filter performing logical AND of several filters.
StorageFilter.CompoundFilter - Class in cz.o2.proxima.core.storage
Filter consisting of several filters with applied function.
StorageFilter.OrFilter - Class in cz.o2.proxima.core.storage
Filter performing logical OR of several filters.
StorageType - Enum in cz.o2.proxima.core.storage
Types of storage.
storesSequentialId() - Method in interface cz.o2.proxima.direct.io.kafka.ElementSerializer
 
storesSequentialId() - Method in class cz.o2.proxima.direct.io.kafka.KafkaStreamElement.KafkaStreamElementSerializer
 
Stream<T> - Interface in cz.o2.proxima.tools.groovy
A stream abstraction with fluent style methods.
StreamConfig - Class in cz.o2.proxima.beam.tools.groovy
Configuration object for BeamStream.
StreamElement - Class in cz.o2.proxima.core.storage
Data wrapper for all ingestion requests.
StreamElement(EntityDescriptor, AttributeDescriptor<?>, long, String, String, long, boolean, byte[]) - Constructor for class cz.o2.proxima.core.storage.StreamElement
 
StreamElement(EntityDescriptor, AttributeDescriptor<?>, String, String, String, long, boolean, byte[]) - Constructor for class cz.o2.proxima.core.storage.StreamElement
 
StreamElementCoder - Class in cz.o2.proxima.beam.core.io
 
StreamElementFilter - Class in cz.o2.proxima.beam.core.transforms
Filter input StreamElement
StreamElementMaterializer - Class in cz.o2.proxima.direct.io.bulkfs.parquet
Class responsible for converting parquet record into StreamElement.
StreamElementMaterializer(MessageType, EntityDescriptor, String) - Constructor for class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementMaterializer
 
StreamElementMaterializer.ParquetColumnGroup - Class in cz.o2.proxima.direct.io.bulkfs.parquet
 
StreamElementMaterializer.ParquetColumnGroup.ParquetColumn - Class in cz.o2.proxima.direct.io.bulkfs.parquet
 
StreamElementMaterializer.ParquetColumnListGroup - Class in cz.o2.proxima.direct.io.bulkfs.parquet
 
StreamElementMaterializer.ParquetColumnListRecordConverter - Class in cz.o2.proxima.direct.io.bulkfs.parquet
 
StreamElementMaterializer.ParquetColumnRecordConverter - Class in cz.o2.proxima.direct.io.bulkfs.parquet
 
StreamElementWriteSupport - Class in cz.o2.proxima.direct.io.bulkfs.parquet
 
StreamElementWriteSupport(MessageType, String) - Constructor for class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementWriteSupport
 
StreamProvider - Interface in cz.o2.proxima.tools.groovy
Provider of Stream based on various parameters.
StreamProvider.TerminatePredicate - Interface in cz.o2.proxima.tools.groovy
 
STRING - cz.o2.proxima.core.scheme.AttributeValueType
 
StringCompressions - Class in cz.o2.proxima.core.util
Utilities related to string compression.
StringConverter<T> - Interface in cz.o2.proxima.direct.io.cassandra
A converter between a specified java type and String.
StringConverter.DefaultConverter - Class in cz.o2.proxima.direct.io.cassandra
 
strings() - Static method in class cz.o2.proxima.core.scheme.SchemaDescriptors
StringUtf8Serializer - Class in cz.o2.proxima.core.scheme
A ValueSerializer for Strings.
StringUtf8Serializer() - Constructor for class cz.o2.proxima.core.scheme.StringUtf8Serializer
 
STRUCTURE - cz.o2.proxima.core.scheme.AttributeValueAccessor.Type
 
STRUCTURE - cz.o2.proxima.core.scheme.AttributeValueType
 
structures(String) - Static method in class cz.o2.proxima.core.scheme.SchemaDescriptors
structures(String, Map<String, SchemaDescriptors.SchemaTypeDescriptor<?>>) - Static method in class cz.o2.proxima.core.scheme.SchemaDescriptors
StructureTypeDescriptor(String, Map<String, SchemaDescriptors.SchemaTypeDescriptor<?>>) - Constructor for class cz.o2.proxima.core.scheme.SchemaDescriptors.StructureTypeDescriptor
 
subscriptionAckDeadline - Variable in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubReader
 
subscriptionAutoCreate - Variable in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubReader
 
sum(Closure<Double>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Sum elements.
sum(String, Closure<Double>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Sum elements.
sumByKey(Closure<K>, Closure<Double>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Sum elements by key.
sumByKey(String, Closure<K>, Closure<Double>) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Sum elements by key.
sync() - Method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.Transaction
 
synchronizedObserver(CommitLogObserver) - Static method in class cz.o2.proxima.direct.core.commitlog.CommitLogObservers
 
synchronizedWriter(OnlineAttributeWriter) - Static method in class cz.o2.proxima.direct.core.OnlineAttributeWriters
A synchronized version of OnlineAttributeWriter.

T

TARGETS - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
TerminationContext - Class in cz.o2.proxima.direct.core.batch
A context that guards correct termination of batch observation process.
TerminationContext(BatchLogObserver) - Constructor for class cz.o2.proxima.direct.core.batch.TerminationContext
 
TestableConnFactory - Class in cz.o2.proxima.direct.io.http
 
TestableConnFactory() - Constructor for class cz.o2.proxima.direct.io.http.TestableConnFactory
 
TestStreamStorage - Class in cz.o2.proxima.beam.storage
Storage with URI scheme test-stream://.
TestStreamStorage() - Constructor for class cz.o2.proxima.beam.storage.TestStreamStorage
 
ThreadPooledObserver - Class in cz.o2.proxima.direct.core.transaction
 
ThreadPooledObserver(ExecutorService, CommitLogObserver, int) - Constructor for class cz.o2.proxima.direct.core.transaction.ThreadPooledObserver
 
ThroughputLimiter - Interface in cz.o2.proxima.core.storage
A limiter of data rate coming from various sources.
ThroughputLimiter.Context - Interface in cz.o2.proxima.core.storage
ThroughputLimiter.NoOpThroughputLimiter - Class in cz.o2.proxima.core.storage
 
timeAveraging(String, String, long) - Method in class cz.o2.proxima.core.metrics.MetricFactory
 
timeAveraging(String, String, long, long, long) - Method in class cz.o2.proxima.core.metrics.MetricFactory
 
TimeAveragingMetric - Class in cz.o2.proxima.core.metrics
Metric calculating average per time window.
TimeProvider - Interface in cz.o2.proxima.core.functional
Provider of timestamp.
timeSlidingWindow(long, long) - Method in interface cz.o2.proxima.tools.groovy.Stream
Create sliding time windowed stream.
TIMESTAMP_SKEW - Static variable in class cz.o2.proxima.direct.core.time.SkewedProcessingTimeIdlePolicy
 
TimestampSupplier - Interface in cz.o2.proxima.direct.core.time
 
timeWindow(long) - Method in interface cz.o2.proxima.tools.groovy.Stream
Create time windowed stream.
TMP_FS - Static variable in class cz.o2.proxima.direct.io.hadoop.HadoopDataAccessor
 
toAttributePrefix() - Method in interface cz.o2.proxima.core.repository.AttributeDescriptor
Retrieve name of the attribute if not wildcard, otherwise retrieve the prefix without the last asterisk.
toAttributePrefix() - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor
 
toAttributePrefix(boolean) - Method in interface cz.o2.proxima.core.repository.AttributeDescriptor
Retrieve name of the attribute if not wildcard, otherwise retrieve the prefix without the last asterisk.
toAttributePrefix(boolean) - Method in class cz.o2.proxima.core.repository.AttributeDescriptorBase
Retrieve name of the attribute if not wildcard, otherwise retrieve the prefix without the last asterisk.
toAttributePrefix(boolean) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor
 
toBuilder(Repository) - Method in interface cz.o2.proxima.core.repository.AttributeDescriptor
Convert this attribute back to builder.
toBuilder(Repository) - Method in class cz.o2.proxima.core.repository.AttributeDescriptorBase
 
toBuilder(Repository) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor
 
toBytes(Offset) - Method in interface cz.o2.proxima.direct.core.commitlog.OffsetExternalizer
Serializes offset to bytes, default implementation uses native java serialization.
toJson(StreamElement) - Method in class cz.o2.proxima.direct.io.elasticsearch.DocumentFormatter.Default
 
toJson(StreamElement) - Method in interface cz.o2.proxima.direct.io.elasticsearch.DocumentFormatter
 
toJson(Offset) - Method in interface cz.o2.proxima.direct.core.commitlog.OffsetExternalizer
Serializes offset to JSON string.
toKey(StreamElement) - Method in interface cz.o2.proxima.direct.io.elasticsearch.DocumentFormatter
 
toKeyValue(EntityDescriptor, AttributeDescriptor<T>, String, String, long, RandomOffset, byte[]) - Method in interface cz.o2.proxima.direct.io.cassandra.CqlFactory
Convert the byte[] stored in the database into KeyValue.
toKeyValue(EntityDescriptor, AttributeDescriptor<T>, String, String, long, RandomOffset, byte[]) - Method in class cz.o2.proxima.direct.io.cassandra.DefaultCqlFactory
 
toKeyValue(EntityDescriptor, AttributeDescriptor<V>, String, String, long, RandomOffset, byte[]) - Method in class cz.o2.proxima.direct.io.cassandra.TransformingCqlFactory
 
toKeyValue(StreamElement) - Static method in class cz.o2.proxima.io.pubsub.util.PubSubUtils
Create PubSub.KeyValue from StreamElement.
ToolsClassLoader - Class in cz.o2.proxima.tools.groovy
GroovyClassLoader keeping track of generated bytecode.
ToolsClassLoader() - Constructor for class cz.o2.proxima.tools.groovy.ToolsClassLoader
 
topic - Variable in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubReader
 
toPrimary() - Method in class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker.OffsetRange
 
toProxy() - Method in class cz.o2.proxima.core.repository.AttributeFamilyDescriptor
Convert this object to proxy descriptor.
toProxy() - Method in class cz.o2.proxima.core.repository.AttributeFamilyProxyDescriptor
 
toProxy(String) - Method in interface cz.o2.proxima.core.transform.ElementWiseProxyTransform
Apply transformation to attribute name to proxy naming.
toProxy(String) - Method in class cz.o2.proxima.core.transform.IdentityTransformation
 
toResult(StreamElement) - Method in interface cz.o2.proxima.flink.core.ResultExtractor
Convert StreamElement into a desired type.
toStreamElement(EntityDescriptor, String, byte[]) - Static method in class cz.o2.proxima.io.pubsub.util.PubSubUtils
Convert pubsub payload into StreamElement.
toStreamElement(EntityDescriptor, String, PubSub.KeyValue) - Static method in class cz.o2.proxima.io.pubsub.util.PubSubUtils
Convert pubsub payload into StreamElement.
toString() - Method in class cz.o2.proxima.core.metrics.Stats
 
toString() - Method in class cz.o2.proxima.core.repository.AttributeDescriptorImpl
 
toString() - Method in class cz.o2.proxima.core.repository.AttributeFamilyDescriptor
 
toString() - Method in class cz.o2.proxima.core.repository.AttributeProxyDescriptor
 
toString() - Method in class cz.o2.proxima.core.repository.ConfigRepository
 
toString() - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor
 
toString() - Method in class cz.o2.proxima.core.repository.EntityDescriptorImpl
 
toString() - Method in class cz.o2.proxima.core.repository.RepositoryFactory.Compressed
 
toString() - Method in class cz.o2.proxima.core.repository.RepositoryFactory.LocalInstance
 
toString() - Method in class cz.o2.proxima.core.repository.RepositoryFactory.VersionedCaching
 
toString() - Method in class cz.o2.proxima.core.repository.TransformationDescriptor
 
toString() - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.ArrayTypeDescriptor
 
toString() - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.EnumTypeDescriptor
 
toString() - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.PrimitiveTypeDescriptor
 
toString() - Method in class cz.o2.proxima.core.scheme.SchemaDescriptors.StructureTypeDescriptor
 
toString() - Method in class cz.o2.proxima.core.storage.StreamElement
 
toString() - Method in class cz.o2.proxima.core.storage.watermark.GlobalWatermarkThroughputLimiter
 
toString() - Method in class cz.o2.proxima.core.util.Pair
 
toString() - Method in class cz.o2.proxima.core.util.SerializableScopedValue
 
toString() - Method in class cz.o2.proxima.core.utils.zookeeper.ZKGlobalWatermarkTracker
 
toString() - Method in class cz.o2.proxima.direct.core.batch.BoundedPartition
 
toString() - Method in class cz.o2.proxima.direct.core.commitlog.CommitLogReaders.LimitedCommitLogReader
 
toString() - Method in class cz.o2.proxima.direct.core.DirectAttributeFamilyDescriptor
 
toString() - Method in class cz.o2.proxima.direct.core.randomaccess.KeyValue
 
toString() - Method in class cz.o2.proxima.direct.core.randomaccess.RawOffset
 
toString() - Method in class cz.o2.proxima.direct.core.time.BoundedOutOfOrdernessWatermarkEstimator.Factory
 
toString() - Method in class cz.o2.proxima.direct.core.time.BoundedOutOfOrdernessWatermarkEstimator
 
toString() - Method in class cz.o2.proxima.direct.core.time.SkewedProcessingTimeIdlePolicy.Factory
 
toString() - Method in class cz.o2.proxima.direct.core.time.SkewedProcessingTimeIdlePolicy
 
toString() - Method in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator.Factory
 
toString() - Method in class cz.o2.proxima.direct.io.blob.BlobPath
 
toString() - Method in class cz.o2.proxima.direct.io.bulkfs.LocalPath
 
toString() - Method in class cz.o2.proxima.direct.io.gcloud.storage.GCloudBlobPath.GCloudBlob
 
toString() - Method in class cz.o2.proxima.direct.io.kafka.KafkaStreamElement
 
toString() - Method in class cz.o2.proxima.direct.io.kafka.KafkaWatermarkConfiguration
 
toString() - Method in class cz.o2.proxima.direct.io.kafka.OffsetCommitter
 
TRANSACTION_ENTITY - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
transactional() - Method in interface cz.o2.proxima.direct.core.OnlineAttributeWriter
 
transactional() - Method in class cz.o2.proxima.direct.core.transaction.TransactionalCachedView
 
transactional() - Method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter
 
TRANSACTIONAL - cz.o2.proxima.core.repository.TransformationDescriptor.InputTransactionMode
The input attributes are *all* transactional attributes.
TRANSACTIONAL - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
TransactionalCachedView - Class in cz.o2.proxima.direct.core.transaction
 
TransactionalCachedView(DirectDataOperator, CachedView) - Constructor for class cz.o2.proxima.direct.core.transaction.TransactionalCachedView
 
TransactionalOnlineAttributeWriter - Class in cz.o2.proxima.direct.core.transaction
A OnlineAttributeWriter that enforces transactions for each write.
TransactionalOnlineAttributeWriter.Transaction - Class in cz.o2.proxima.direct.core.transaction
 
TransactionalOnlineAttributeWriter.TransactionAware - Interface in cz.o2.proxima.direct.core.transaction
Interface for a transformation to get access to TransactionalOnlineAttributeWriter.Transaction.
TransactionalOnlineAttributeWriter.TransactionPreconditionFailedException - Exception in cz.o2.proxima.direct.core.transaction
 
TransactionalOnlineAttributeWriter.TransactionRejectedException - Exception in cz.o2.proxima.direct.core.transaction
 
TransactionalOnlineAttributeWriter.TransactionRejectedRuntimeException - Exception in cz.o2.proxima.direct.core.transaction
This exception might be thrown in place of TransactionalOnlineAttributeWriter.TransactionRejectedException where from TransactionalOnlineAttributeWriter.TransactionAware transformations where the ElementWiseTransformation.apply(StreamElement, Collector) does not allow for throwing checked exceptions directly.
TransactionalOnlineAttributeWriter.TransactionValidator - Class in cz.o2.proxima.direct.core.transaction
Base class for enforcing constraints on outputs of transaction (e.g.
TransactionCommitTransformation - Class in cz.o2.proxima.direct.core.transaction
 
TransactionCommitTransformation() - Constructor for class cz.o2.proxima.direct.core.transaction.TransactionCommitTransformation
 
TransactionCommitTransformProvider - Class in cz.o2.proxima.direct.core.transaction
 
TransactionCommitTransformProvider() - Constructor for class cz.o2.proxima.direct.core.transaction.TransactionCommitTransformProvider
 
TransactionContext - Class in cz.o2.proxima.direct.server.transaction
A per-transaction context shared between RetrieveService and IngestService.
TransactionContext(DirectDataOperator) - Constructor for class cz.o2.proxima.direct.server.transaction.TransactionContext
 
TransactionContext.Transaction - Interface in cz.o2.proxima.direct.server.transaction
 
TransactionLogObserver - Class in cz.o2.proxima.direct.transaction.manager
A CommitLogObserver performing the overall transaction logic via keeping state of transactions and responding to requests.
TransactionLogObserver(DirectDataOperator, Metrics) - Constructor for class cz.o2.proxima.direct.transaction.manager.TransactionLogObserver
 
TransactionLogObserverFactory - Interface in cz.o2.proxima.direct.transaction.manager
 
TransactionLogObserverFactory.Default - Class in cz.o2.proxima.direct.transaction.manager
 
TransactionLogObserverFactory.WithOnErrorHandler - Class in cz.o2.proxima.direct.transaction.manager
 
TransactionManager - Interface in cz.o2.proxima.direct.core.transaction
 
TransactionManager.TransactionConfig - Interface in cz.o2.proxima.direct.core.transaction
 
TransactionManagerServer - Class in cz.o2.proxima.direct.transaction.manager
A transaction manager that takes a Repository with configured transactional entities and attributes and runs (possibly distributed) transaction manager.
transactionMode - Variable in class cz.o2.proxima.core.repository.AttributeDescriptorBase
 
TransactionMode - Enum in cz.o2.proxima.core.repository
Type of transactions of a AttributeDescriptor.
TransactionMonitoringPolicy - Interface in cz.o2.proxima.direct.core.transaction
Policy that can be specified for monitoring transactions during execution.
TransactionPartitioner - Class in cz.o2.proxima.core.transaction
 
TransactionPartitioner() - Constructor for class cz.o2.proxima.core.transaction.TransactionPartitioner
 
TransactionPreconditionFailedException(String) - Constructor for exception cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.TransactionPreconditionFailedException
 
TransactionRejectedException(String, Response.Flags) - Constructor for exception cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.TransactionRejectedException
 
TransactionRejectedException(String, Response.Flags, Throwable) - Constructor for exception cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.TransactionRejectedException
 
TransactionRejectedRuntimeException(TransactionalOnlineAttributeWriter.TransactionRejectedException) - Constructor for exception cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.TransactionRejectedRuntimeException
 
TransactionResourceManager - Class in cz.o2.proxima.direct.core.transaction
Manager of open transactional resources - e.g.
TransactionResourceManager(DirectDataOperator, Map<String, Object>) - Constructor for class cz.o2.proxima.direct.core.transaction.TransactionResourceManager
 
TRANSACTIONS - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
TransactionSerializerSchemeProvider - Interface in cz.o2.proxima.core.transaction
A provider of schemes for Request, Response and State.
TransactionTransformProvider - Interface in cz.o2.proxima.core.transaction
Provider of Transformation that is used when transforming _transaction.commit requests to target families.
TransactionUpdate() - Constructor for class cz.o2.proxima.core.transaction.Commit.TransactionUpdate
 
TransactionValidator() - Constructor for class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.TransactionValidator
 
transform(StreamElement, CommitCallback) - Method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.TransactionValidator
 
transform(StreamElement, CommitCallback) - Method in class cz.o2.proxima.direct.core.transaction.TransactionCommitTransformation
 
transform(StreamElement, CommitCallback) - Method in interface cz.o2.proxima.direct.core.transform.DirectElementWiseTransform
Transform and output any transformed elements.
Transformation - Interface in cz.o2.proxima.core.transform
 
TransformationDescriptor - Class in cz.o2.proxima.core.repository
Descriptor of single transformation specified in transformations.
TransformationDescriptor.InputTransactionMode - Enum in cz.o2.proxima.core.repository
Mode of handling transactional attributes on input.
TransformationDescriptor.OutputTransactionMode - Enum in cz.o2.proxima.core.repository
Mode of handling transactional attribute on output.
TransformationObserver - Class in cz.o2.proxima.direct.core.transform
Observer of source data performing transformation to another entity/attribute.
TransformationObserver.Contextual - Class in cz.o2.proxima.direct.core.transform
 
TransformationObserver.NonContextual - Class in cz.o2.proxima.direct.core.transform
 
TransformingCqlFactory<T extends java.io.Serializable> - Class in cz.o2.proxima.direct.io.cassandra
A CQL factory that stores data in other fields than what would suggest the model itself.
TransformingCqlFactory(UnaryFunction<StreamElement, T>, List<String>, List<UnaryFunction<Pair<String, T>, Object>>) - Constructor for class cz.o2.proxima.direct.io.cassandra.TransformingCqlFactory
 
TransformingCqlFactory(UnaryFunction<StreamElement, T>, List<String>, List<UnaryFunction<Pair<String, T>, Object>>, UnaryFunction<T, Boolean>) - Constructor for class cz.o2.proxima.direct.io.cassandra.TransformingCqlFactory
 
TriFunction<F,​S,​T,​R> - Interface in cz.o2.proxima.core.functional
FUnction of three arguments.
tryClaim(Partition) - Method in class cz.o2.proxima.beam.core.direct.io.BatchRestrictionTracker
 
tryClaim(Offset) - Method in class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker
 
trySplit(double) - Method in class cz.o2.proxima.beam.core.direct.io.BatchRestrictionTracker
 
trySplit(double) - Method in class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker
 
ttl - Variable in class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory
A TTL value in seconds associated with each update or insert.
TupleCoder - Class in cz.o2.proxima.beam.tools.groovy
Coder for Tuples.
TupleSerializer - Class in cz.o2.proxima.beam.tools.groovy
Kryo serializer for Tuples.
TupleSerializer() - Constructor for class cz.o2.proxima.beam.tools.groovy.TupleSerializer
 
TYPE - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
TYPE_CHECK_ERROR_MESSAGE_TEMPLATE - Static variable in interface cz.o2.proxima.core.scheme.SchemaDescriptors.SchemaTypeDescriptor
 
Types - Class in cz.o2.proxima.tools.groovy.util
Various type-related utilities.

U

UnaryFunction<IN,​OUT> - Interface in cz.o2.proxima.core.functional
Function of single argument.
UnaryPredicate<T> - Interface in cz.o2.proxima.core.functional
Predicate that is Serializable.
UnboundedOutOfOrdernessWatermarkEstimator - Class in cz.o2.proxima.direct.core.time
Estimator of watermark based on timestamps of flowing elements.
UnboundedOutOfOrdernessWatermarkEstimator.Builder - Class in cz.o2.proxima.direct.core.time
UnboundedOutOfOrdernessWatermarkEstimator.Factory - Class in cz.o2.proxima.direct.core.time
 
unchecked(ExceptionUtils.ThrowingRunnable) - Static method in class cz.o2.proxima.core.util.ExceptionUtils
Run given runnable rethrowing exceptions as RuntimeExceptions.
uncheckedBiConsumer(ExceptionUtils.ThrowingBiConsumer<A, B>) - Static method in class cz.o2.proxima.core.util.ExceptionUtils
 
uncheckedConsumer(ExceptionUtils.ThrowingConsumer<T>) - Static method in class cz.o2.proxima.core.util.ExceptionUtils
Wrap consumer throwing exceptions to regular consumer.
uncheckedFactory(ExceptionUtils.ThrowingFactory<T>) - Static method in class cz.o2.proxima.core.util.ExceptionUtils
Run given factory and return result.
uncheckedFn(ExceptionUtils.ThrowingUnaryFunction<IN, OUT>) - Static method in class cz.o2.proxima.core.util.ExceptionUtils
Wrap throwing unary function as regular one.
union(Stream<T>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Merge two streams together.
union(String, Stream<T>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Merge two streams together.
union(String, List<Stream<T>>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Merge multiple streams together.
union(List<Stream<T>>) - Method in interface cz.o2.proxima.tools.groovy.Stream
Merge multiple streams together.
UNKNOWN - cz.o2.proxima.core.transaction.State.Flags
 
untilTimestamp(long) - Static method in class cz.o2.proxima.beam.core.transforms.StreamElementFilter
Filter StreamElement with lower timestamp
untilTimestamp(Instant) - Static method in class cz.o2.proxima.beam.core.transforms.StreamElementFilter
Filter StreamElement with lower timestamp
update(int, StreamElement) - Method in interface cz.o2.proxima.core.time.PartitionedWatermarkEstimator
Updates the partition watermark estimate according to the given stream element.
update(int, StreamElement) - Method in class cz.o2.proxima.direct.core.time.MinimalPartitionWatermarkEstimator
 
update(HikariDataSource, StreamElement) - Method in interface cz.o2.proxima.direct.jdbc.SqlStatementFactory
 
update(StreamElement) - Method in class cz.o2.proxima.core.time.AbstractWatermarkEstimator
Updates the watermark estimate according to the given stream element.
update(StreamElement) - Method in interface cz.o2.proxima.core.time.WatermarkEstimator
Updates the watermark estimate according to the given stream element.
update(StreamElement) - Method in interface cz.o2.proxima.core.time.WatermarkIdlePolicy
Updates policy state when a new element is received from streaming source.
update(StreamElement) - Method in class cz.o2.proxima.direct.core.time.ProcessingTimeShiftingWatermarkIdlePolicy
 
update(String, long) - Method in interface cz.o2.proxima.core.storage.watermark.GlobalWatermarkTracker
Update watermark of given process.
update(String, long) - Method in class cz.o2.proxima.core.utils.zookeeper.ZKGlobalWatermarkTracker
 
update(String, long) - Method in class cz.o2.proxima.flink.utils.FlinkGlobalWatermarkTracker
 
update(Collection<KeyAttribute>) - Method in class cz.o2.proxima.core.transaction.State
 
update(List<KeyAttribute>) - Method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.Transaction
 
update(List<KeyAttribute>) - Method in interface cz.o2.proxima.direct.server.transaction.TransactionContext.Transaction
 
UPDATE - cz.o2.proxima.core.transaction.Request.Flags
 
UPDATE_REQUESTS - Static variable in class cz.o2.proxima.direct.server.metrics.Metrics
 
updated() - Method in class cz.o2.proxima.core.transaction.Response
 
UPDATED - cz.o2.proxima.core.transaction.Response.Flags
 
updates(Collection<Commit.TransactionUpdate>) - Static method in class cz.o2.proxima.core.transaction.Commit
Create new Commit message to be appended to _transcation.commit
updateTransaction(String, List<KeyAttribute>) - Method in interface cz.o2.proxima.direct.core.transaction.ClientTransactionManager
Update the transaction with additional attributes related to the transaction.
updateTransaction(String, List<KeyAttribute>) - Method in class cz.o2.proxima.direct.core.transaction.TransactionResourceManager
Update the transaction with additional attributes related to the transaction.
updateWatermark(long) - Method in interface cz.o2.proxima.direct.core.BulkAttributeWriter
Update watermark when no input data arrives.
updateWatermark(long) - Method in class cz.o2.proxima.direct.io.blob.BulkBlobWriter
 
updateWatermark(long) - Method in class cz.o2.proxima.direct.io.bulkfs.AbstractBulkFileSystemAttributeWriter
 
updateWatermark(StreamElement) - Method in class cz.o2.proxima.core.time.AbstractWatermarkEstimator
Updates the watermark estimate according to given stream element.
updateWatermark(StreamElement) - Method in class cz.o2.proxima.direct.core.time.BoundedOutOfOrdernessWatermarkEstimator
 
updateWatermark(StreamElement) - Method in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator
 
upsert(long, String, long, T) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Regular
Create upsert update to non-wildcard attribute.
upsert(long, String, String, long, T) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Wildcard
Create upsert update to wildcard attribute.
upsert(EntityDescriptor, AttributeDescriptor<?>, long, String, String, long, byte[]) - Static method in class cz.o2.proxima.core.storage.StreamElement
Upsert given entity attribute with given value.
upsert(EntityDescriptor, AttributeDescriptor<?>, String, String, String, long, byte[]) - Static method in class cz.o2.proxima.core.storage.StreamElement
Upsert given entity attribute with given value.
upsert(String, long, T) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Regular
Create upsert update to non-wildcard attribute.
upsert(String, String, long, T) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Regular
Create upsert update to non-wildcard attribute.
upsert(String, String, long, T) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Wildcard
Create upsert update to wildcard attribute.
upsert(String, String, String, long, T) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Wildcard
Create upsert update to wildcard attribute.
upsert(String, String, String, Instant, T) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Wildcard
Create upsert update to wildcard attribute.
upsert(String, String, Instant, T) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Regular
Create upsert update to non-wildcard attribute.
upsert(String, String, Instant, T) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Wildcard
Create upsert update to wildcard attribute.
upsert(String, Instant, T) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Regular
Create upsert update to non-wildcard attribute.
UriUtil - Class in cz.o2.proxima.core.storage
Utilities related to URIs.
UUID_HEADER - Static variable in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
A name for a header containing UUID of StreamElement

V

validate(StreamElement, TransactionalOnlineAttributeWriter.Transaction) - Method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.TransactionValidator
Validate the input element.
VALIDATIONS - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
value() - Method in annotation type cz.o2.proxima.core.annotations.Evolving
 
value() - Method in annotation type cz.o2.proxima.core.annotations.Experimental
 
value() - Method in interface cz.o2.proxima.core.scheme.AttributeValueAccessors.StructureValue
Return map with values
value() - Method in class cz.o2.proxima.core.scheme.AttributeValueAccessors.StructureValueImpl
 
ValueAsBytesSerializer - Class in cz.o2.proxima.direct.io.kafka.serializer
A ElementSerializer that reads values from kafka (discards keys) and returns values as byte arrays.
ValueAsBytesSerializer(UnaryFunction<EntityDescriptor, AttributeDescriptor<byte[]>>) - Constructor for class cz.o2.proxima.direct.io.kafka.serializer.ValueAsBytesSerializer
 
ValueAsBytesSerializer(String) - Constructor for class cz.o2.proxima.direct.io.kafka.serializer.ValueAsBytesSerializer
 
ValueAsStringSerializer - Class in cz.o2.proxima.direct.io.kafka.serializer
 
ValueAsStringSerializer(UnaryFunction<EntityDescriptor, AttributeDescriptor<String>>) - Constructor for class cz.o2.proxima.direct.io.kafka.serializer.ValueAsStringSerializer
 
ValueAsStringSerializer(String) - Constructor for class cz.o2.proxima.direct.io.kafka.serializer.ValueAsStringSerializer
 
valueOf(StreamElement) - Method in interface cz.o2.proxima.core.repository.AttributeDescriptor
 
valueOf(StreamElement) - Method in class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor
 
valueOf(InputT) - Method in interface cz.o2.proxima.core.scheme.AttributeValueAccessor
Get value of attribute.
valueOf(String) - Static method in enum cz.o2.proxima.core.repository.Repository.Validate
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cz.o2.proxima.core.repository.TransactionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cz.o2.proxima.core.repository.TransformationDescriptor.InputTransactionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cz.o2.proxima.core.repository.TransformationDescriptor.OutputTransactionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cz.o2.proxima.core.scheme.AttributeValueAccessor.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cz.o2.proxima.core.scheme.AttributeValueType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cz.o2.proxima.core.storage.commitlog.Position
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cz.o2.proxima.core.storage.internal.AbstractDataAccessorFactory.Accept
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cz.o2.proxima.core.storage.StorageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cz.o2.proxima.core.transaction.Request.Flags
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cz.o2.proxima.core.transaction.Response.Flags
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cz.o2.proxima.core.transaction.State.Flags
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cz.o2.proxima.core.util.CamelCase.Characters
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cz.o2.proxima.direct.core.AttributeWriterBase.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cz.o2.proxima.direct.core.commitlog.CommitLogObservers.TerminationStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cz.o2.proxima.direct.core.randomaccess.RandomAccessReader.Listing
Returns the enum constant of this type with the specified name.
valueOf(List<T>) - Method in interface cz.o2.proxima.core.scheme.AttributeValueAccessors.ArrayValueAccessor
 
valueOf(T) - Method in class cz.o2.proxima.core.scheme.AttributeValueAccessors.PrimitiveValueAccessorImpl
 
valueOf(T) - Method in class cz.o2.proxima.scheme.proto.ProtoMessageValueAccessor
 
values() - Static method in enum cz.o2.proxima.core.repository.Repository.Validate
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cz.o2.proxima.core.repository.TransactionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cz.o2.proxima.core.repository.TransformationDescriptor.InputTransactionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cz.o2.proxima.core.repository.TransformationDescriptor.OutputTransactionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cz.o2.proxima.core.scheme.AttributeValueAccessor.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class cz.o2.proxima.core.scheme.AttributeValueAccessors.StructureValueImpl
 
values() - Static method in enum cz.o2.proxima.core.scheme.AttributeValueType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cz.o2.proxima.core.storage.commitlog.Position
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cz.o2.proxima.core.storage.internal.AbstractDataAccessorFactory.Accept
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cz.o2.proxima.core.storage.StorageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cz.o2.proxima.core.transaction.Request.Flags
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cz.o2.proxima.core.transaction.Response.Flags
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cz.o2.proxima.core.transaction.State.Flags
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cz.o2.proxima.core.util.CamelCase.Characters
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cz.o2.proxima.direct.core.AttributeWriterBase.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cz.o2.proxima.direct.core.commitlog.CommitLogObservers.TerminationStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cz.o2.proxima.direct.core.randomaccess.RandomAccessReader.Listing
Returns an array containing the constants of this enum type, in the order they are declared.
valueSerde() - Method in interface cz.o2.proxima.direct.io.kafka.ElementSerializer
Retrieve Serde for type V.
valueSerde() - Method in class cz.o2.proxima.direct.io.kafka.KafkaStreamElement.KafkaStreamElementSerializer
 
valueSerde() - Method in class cz.o2.proxima.direct.io.kafka.serializer.ValueAsBytesSerializer
 
valueSerde() - Method in class cz.o2.proxima.direct.io.kafka.serializer.ValueAsStringSerializer
 
valueSerializer - Variable in class cz.o2.proxima.core.repository.AttributeDescriptorBase
 
ValueSerializer<T> - Interface in cz.o2.proxima.core.scheme
A serializer of values with specified scheme.
ValueSerializer.InitializedWithRepository - Interface in cz.o2.proxima.core.scheme
When a ValueSerializer needs to be initialized with Repository instance after the Repository has need created and initialized, it can implement this interface.
ValueSerializerFactory - Interface in cz.o2.proxima.core.scheme
Factory for ValueSerializer.
verifyCleanupPolicy(ConfigEntry) - Method in class cz.o2.proxima.direct.io.kafka.KafkaAccessor
 
verifyCompatibility(WindowFn<?, ?>) - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.DaysWindows
 
verifyCompatibility(WindowFn<?, ?>) - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.MonthsWindows
 
verifyCompatibility(WindowFn<?, ?>) - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.YearsWindows
 
verifyDeterministic() - Method in class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource.CheckpointCoder
 
verifyDeterministic() - Method in class cz.o2.proxima.beam.core.io.AttributeDescriptorCoder
 
verifyDeterministic() - Method in class cz.o2.proxima.beam.core.io.EntityDescriptorCoder
 
verifyDeterministic() - Method in class cz.o2.proxima.beam.core.io.PairCoder
 
verifyDeterministic() - Method in class cz.o2.proxima.beam.core.io.StreamElementCoder
 
verifyDeterministic() - Method in class cz.o2.proxima.beam.tools.groovy.TupleCoder
 
VIA - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
VoidConsumer - Interface in cz.o2.proxima.core.functional
A function of zero arguments returning void.

W

waitUntilReady() - Method in interface cz.o2.proxima.direct.core.commitlog.ObserveHandle
Wait until the consumer is ready to read data.
WatermarkConfiguration - Class in cz.o2.proxima.direct.core.time
Watermark configuration
WatermarkConfiguration(Map<String, Object>) - Constructor for class cz.o2.proxima.direct.core.time.WatermarkConfiguration
 
WatermarkEstimator - Interface in cz.o2.proxima.core.time
Estimates watermark according to incoming stream elements.
WatermarkEstimatorFactory - Interface in cz.o2.proxima.core.time
Factory creates watermark estimator instance.
watermarkFactory - Variable in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubReader
 
WatermarkIdlePolicy - Interface in cz.o2.proxima.core.time
Policy defines behaviour how watermark should behave when streaming source is idle
WatermarkIdlePolicyFactory - Interface in cz.o2.proxima.core.time
Factory creates watermark idle policy instance.
Watermarks - Class in cz.o2.proxima.core.time
 
WatermarkSupplier - Interface in cz.o2.proxima.core.time
Supplies the current watermark to clients.
WebsocketReader - Class in cz.o2.proxima.direct.io.http
Reader of data from websocket (ws, or wss).
WebsocketReader(EntityDescriptor, URI, Map<String, Object>) - Constructor for class cz.o2.proxima.direct.io.http.WebsocketReader
 
weeks(int, int) - Static method in class cz.o2.proxima.beam.core.transforms.CalendarWindows
Returns a WindowFn that windows elements into periods measured by weeks.
wildcard - Variable in class cz.o2.proxima.core.repository.AttributeDescriptorBase
 
windowAll() - Method in interface cz.o2.proxima.tools.groovy.Stream
Group all elements into single window.
windowCoder() - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.DaysWindows
 
windowCoder() - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.MonthsWindows
 
windowCoder() - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.YearsWindows
 
WindowedStream<T> - Interface in cz.o2.proxima.tools.groovy
A stream that is windowed.
withAllowedLateness(long) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Specify allowed lateness for windowed operations.
withAllowedTimestampSkew(long) - Method in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator.Builder
 
withCachingEnabled(boolean) - Method in class cz.o2.proxima.core.repository.ConfigRepository.Builder
 
withDurationMs(long) - Method in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator.Builder
 
withEarlyEmitting(long) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
Specify early emitting for windowed operations
withExecutorFactory(Factory<ExecutorService>) - Method in class cz.o2.proxima.direct.core.DirectDataOperator
Explicitly specify ExecutorService to use when constructing threads.
withLimitedThroughput(BatchLogReader, ThroughputLimiter) - Static method in class cz.o2.proxima.direct.core.batch.BatchLogReaders
Create throughput limited BatchLogReader.
withLoadClasses(boolean) - Method in class cz.o2.proxima.core.repository.ConfigRepository.Builder
 
withLoadFamilies(boolean) - Method in class cz.o2.proxima.core.repository.ConfigRepository.Builder
 
withMaxOutOfOrderness(long) - Method in class cz.o2.proxima.direct.core.time.BoundedOutOfOrdernessWatermarkEstimator.Builder
 
withMinimalTimestamp(int, long) - Static method in interface cz.o2.proxima.core.storage.Partition
Wrap numerical id to Partition with given minimal timestamp.
withMinWatermark(long) - Method in class cz.o2.proxima.direct.core.time.BoundedOutOfOrdernessWatermarkEstimator.Builder
 
withMinWatermark(long) - Method in class cz.o2.proxima.direct.core.time.ProcessingTimeWatermarkEstimator.Builder
 
withMinWatermark(long) - Method in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator.Builder
 
withNumRetriedExceptions(String, int, UnaryFunction<Throwable, CommitLogObservers.TerminationStrategy>, CommitLogObserver) - Static method in class cz.o2.proxima.direct.core.commitlog.CommitLogObservers
Create a CommitLogObserver that handles retries on Exceptions thrown during processing.
withNumRetriedExceptions(String, int, CommitLogObserver) - Static method in class cz.o2.proxima.direct.core.commitlog.CommitLogObservers
Create a CommitLogObserver that handles retries on Exceptions thrown during processing.
withNumRetriedThrowables(String, int, UnaryFunction<Throwable, CommitLogObservers.TerminationStrategy>, CommitLogObserver) - Static method in class cz.o2.proxima.direct.core.commitlog.CommitLogObservers
Create a CommitLogObserver that handles retries on Throwables thrown during processing.
withReadOnly(boolean) - Method in class cz.o2.proxima.core.repository.ConfigRepository.Builder
 
withResponsePartitionId(int) - Method in class cz.o2.proxima.core.transaction.Request
 
withRetryableException(Class<? extends Exception>) - Method in class cz.o2.proxima.direct.io.blob.RetryStrategy
 
withSortBuffer(CommitLogObserver, Duration) - Static method in class cz.o2.proxima.direct.core.commitlog.CommitLogObservers
Create CommitLogObserver that observes data in event time order.
withSortBuffer(CommitLogObserver, Duration, BiConsumer<StreamElement, CommitLogObserver.OnNextContext>) - Static method in class cz.o2.proxima.direct.core.commitlog.CommitLogObservers
Create CommitLogObserver that observes data in event time order.
withSortBuffer(CommitLogObserver, Duration, Consumer<StreamElement>) - Static method in class cz.o2.proxima.direct.core.commitlog.CommitLogObservers
Create CommitLogObserver that observes data in event time order.
withSortBufferWithinPartition(CommitLogObserver, Duration) - Static method in class cz.o2.proxima.direct.core.commitlog.CommitLogObservers
Create CommitLogObserver that observes data in event time order per partition.
withSortBufferWithinPartition(CommitLogObserver, Duration, BiConsumer<StreamElement, CommitLogObserver.OnNextContext>) - Static method in class cz.o2.proxima.direct.core.commitlog.CommitLogObservers
Create CommitLogObserver that observes data in event time order per partition.
withSortBufferWithinPartition(CommitLogObserver, Duration, Consumer<StreamElement>) - Static method in class cz.o2.proxima.direct.core.commitlog.CommitLogObservers
Create CommitLogObserver that observes data in event time order per partition.
withStartingDay(Instant) - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.DaysWindows
 
withStartingMonth(int, int) - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.MonthsWindows
 
withStartingYear(int) - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.YearsWindows
 
withStepMs(long) - Method in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator.Builder
 
withStorageReplacement(Config, UnaryPredicate<String>, UnaryFunction<String, URI>) - Static method in class cz.o2.proxima.core.repository.config.ConfigUtils
Create new Config from given one with storages of selected attribute families replaced by given URI.
withThroughputLimit(CommitLogReader, ThroughputLimiter) - Static method in class cz.o2.proxima.direct.core.commitlog.CommitLogReaders
Create throughput limited CommitLogReader.
withTimestamp() - Method in interface cz.o2.proxima.tools.groovy.Stream
Add timestamp to each element in the stream.
withTimestamp() - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
 
withTimestamp(String) - Method in interface cz.o2.proxima.tools.groovy.Stream
Add timestamp to each element in the stream.
withTimestamp(String) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
 
withTimestampSupplier(TimestampSupplier) - Method in class cz.o2.proxima.direct.core.time.ProcessingTimeWatermarkEstimator.Builder
 
withTimestampSupplier(TimestampSupplier) - Method in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator.Builder
 
withTimeZone(TimeZone) - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.DaysWindows
 
withTimeZone(TimeZone) - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.MonthsWindows
 
withTimeZone(TimeZone) - Method in class cz.o2.proxima.beam.core.transforms.CalendarWindows.YearsWindows
 
withValidate(Repository.Validate...) - Method in class cz.o2.proxima.core.repository.ConfigRepository.Builder
 
withValidateFlag(int) - Method in class cz.o2.proxima.core.repository.ConfigRepository.Builder
 
withWatermark(Partition, Offset, long) - Static method in class cz.o2.proxima.direct.core.batch.BatchLogObservers
Create BatchLogObserver.OnNextContext which sets watermark ti given epoch millis.
withWatermarkIdlePolicy(WatermarkIdlePolicy) - Method in class cz.o2.proxima.direct.core.time.BoundedOutOfOrdernessWatermarkEstimator.Builder
 
withWatermarkIdlePolicy(WatermarkIdlePolicy) - Method in class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator.Builder
 
withWatermarkSupplier(Partition, Offset, WatermarkSupplier) - Static method in class cz.o2.proxima.direct.core.batch.BatchLogObservers
Create BatchLogObserver.OnNextContext which moves watermark according to given WatermarkSupplier.
withWindow() - Method in interface cz.o2.proxima.tools.groovy.Stream
Add window to each element in the stream.
withWindow() - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
 
withWindow(String) - Method in interface cz.o2.proxima.tools.groovy.Stream
Add window to each element in the stream.
withWindow(String) - Method in interface cz.o2.proxima.tools.groovy.WindowedStream
 
wrap(Repository, PCollection<T>) - Static method in class cz.o2.proxima.beam.tools.groovy.BeamStreamProvider
Create a Stream from given PCollection.
write() - Method in interface cz.o2.proxima.direct.io.bulkfs.Path
Open writeable byte channel to a given Path.
write(RepositoryFactory) - Static method in class cz.o2.proxima.beam.io.ProximaIO
Write stream elements into proxima using DirectDataOperator.
write(StreamElement) - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.ProximaParquetWriter
 
write(StreamElement) - Method in class cz.o2.proxima.direct.io.bulkfs.parquet.StreamElementWriteSupport
 
write(StreamElement) - Method in interface cz.o2.proxima.direct.io.bulkfs.Writer
Write StreamElement into this blob store.
write(StreamElement, long, CommitCallback) - Method in interface cz.o2.proxima.direct.core.BulkAttributeWriter
Write given serialized attribute value to given entity.
write(StreamElement, long, CommitCallback) - Method in class cz.o2.proxima.direct.io.blob.BulkBlobWriter
 
write(StreamElement, long, CommitCallback) - Method in class cz.o2.proxima.direct.io.bulkfs.AbstractBulkFileSystemAttributeWriter
 
write(StreamElement, long, CommitCallback) - Method in class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchWriter
 
write(StreamElement, CommitCallback) - Method in interface cz.o2.proxima.direct.core.OnlineAttributeWriter
Write given serialized attribute value to given entity.
write(StreamElement, CommitCallback) - Method in class cz.o2.proxima.direct.core.transaction.TransactionalCachedView
 
write(StreamElement, CommitCallback) - Method in class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter
 
write(StreamElement, CommitCallback) - Method in class cz.o2.proxima.direct.core.view.LocalCachedPartitionedView
 
write(StreamElement, CommitCallback) - Method in class cz.o2.proxima.direct.io.http.HttpWriter
 
write(StreamElement, CommitCallback) - Method in class cz.o2.proxima.direct.io.kafka.KafkaWriter
 
write(StreamElement, CommitCallback) - Method in class cz.o2.proxima.direct.jdbc.JdbcOnlineAttributeWriter
 
write(RepositoryProvider) - Method in interface cz.o2.proxima.tools.groovy.Stream
Directly write this stream to repository.
write(String, int, StreamElement) - Method in interface cz.o2.proxima.direct.io.kafka.ElementSerializer
Convert StreamElement into ProducerRecord.
write(String, int, StreamElement) - Method in class cz.o2.proxima.direct.io.kafka.KafkaStreamElement.KafkaStreamElementSerializer
 
write(String, int, StreamElement) - Method in class cz.o2.proxima.direct.io.kafka.serializer.ValueAsBytesSerializer
 
write(String, int, StreamElement) - Method in class cz.o2.proxima.direct.io.kafka.serializer.ValueAsStringSerializer
 
write(Kryo, Output, GString) - Method in class cz.o2.proxima.beam.tools.groovy.GStringSerializer
 
write(Kryo, Output, Tuple<Object>) - Method in class cz.o2.proxima.beam.tools.groovy.TupleSerializer
 
WRITE - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
WRITE_ONLY - Static variable in class cz.o2.proxima.core.repository.ConfigConstants
 
writeMessage(String, long, Message, CommitCallback) - Method in class cz.o2.proxima.direct.io.pubsub.AbstractPubSubWriter
 
writer() - Method in class cz.o2.proxima.direct.io.blob.BlobPath
 
writer() - Method in class cz.o2.proxima.direct.io.bulkfs.LocalPath
 
writer() - Method in interface cz.o2.proxima.direct.io.bulkfs.Path
Deprecated.
Use Path.write() instead.
writer() - Method in class cz.o2.proxima.direct.io.gcloud.storage.GCloudBlobPath
 
writer() - Method in class cz.o2.proxima.direct.io.s3.S3BlobPath
 
Writer - Interface in cz.o2.proxima.direct.io.bulkfs
Proxima's abstraction of writer for bulk data.
writeResponseAndUpdateState(String, State, String, Response, CommitCallback) - Method in interface cz.o2.proxima.direct.core.transaction.ServerTransactionManager
Atomically write response and update state of a transaction
writeResponseAndUpdateState(String, State, String, Response, CommitCallback) - Method in class cz.o2.proxima.direct.core.transaction.TransactionResourceManager
 

Y

years(int) - Static method in class cz.o2.proxima.beam.core.transforms.CalendarWindows
Returns a WindowFn that windows elements into periods measured by years.

Z

ZK_SESSION_TIMEOUT - Static variable in class cz.o2.proxima.core.utils.zookeeper.ZKGlobalWatermarkTracker
 
ZK_URI - Static variable in class cz.o2.proxima.core.utils.zookeeper.ZKGlobalWatermarkTracker
 
ZKGlobalWatermarkTracker - Class in cz.o2.proxima.core.utils.zookeeper
A GlobalWatermarkTracker that stores global information in Apache Zookeeper.
ZKGlobalWatermarkTracker() - Constructor for class cz.o2.proxima.core.utils.zookeeper.ZKGlobalWatermarkTracker
 
A B C D E F G H I J K L M N O P R S T U V W Y Z 
All Classes All Packages