Serialized Form
-
Package cz.o2.proxima.beam.core
-
Class cz.o2.proxima.beam.core.AttributeFamilyProxyDataAccessor extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
lookupProxy
java.util.Map<AttributeProxyDescriptor<?>,AttributeDescriptor<?>> lookupProxy
-
lookupTarget
java.util.Map<AttributeDescriptor<?>,AttributeProxyDescriptor<?>> lookupTarget
-
proxy
AttributeFamilyProxyDescriptor proxy
-
readAccessor
DataAccessor readAccessor
-
writeAccessor
DataAccessor writeAccessor
-
-
Class cz.o2.proxima.beam.core.BeamProxyTransform extends java.lang.Object implements Serializable
-
-
Package cz.o2.proxima.beam.core.direct.io
-
Class cz.o2.proxima.beam.core.direct.io.BatchLogRead extends org.apache.beam.sdk.transforms.PTransform<org.apache.beam.sdk.values.PBegin,org.apache.beam.sdk.values.PCollection<StreamElement>> implements Serializable
-
Serialized Fields
-
attributes
java.util.List<AttributeDescriptor<?>> attributes
-
endStamp
long endStamp
-
limit
long limit
-
maxInitialSplits
int maxInitialSplits
-
readerFactory
BatchLogReader.Factory<?> readerFactory
-
repoFactory
RepositoryFactory repoFactory
-
startStamp
long startStamp
-
-
-
Class cz.o2.proxima.beam.core.direct.io.BatchRestrictionTracker.PartitionList extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
partitions
java.util.List<Partition> partitions
-
totalLimit
long totalLimit
-
-
Class cz.o2.proxima.beam.core.direct.io.CommitLogRead extends org.apache.beam.sdk.transforms.PTransform<org.apache.beam.sdk.values.PBegin,org.apache.beam.sdk.values.PCollection<StreamElement>> implements Serializable
-
Serialized Fields
-
bounded
boolean bounded
-
limit
long limit
-
observeName
java.lang.String observeName
-
position
Position position
-
readerFactory
CommitLogReader.Factory<?> readerFactory
-
repoFactory
RepositoryFactory repoFactory
-
-
-
Class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource extends org.apache.beam.sdk.io.UnboundedSource<StreamElement,DirectBatchUnboundedSource.Checkpoint> implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readObject
private void readObject(java.io.ObjectInputStream stream) throws java.io.IOException, java.lang.ClassNotFoundException
- Throws:
java.io.IOException
java.lang.ClassNotFoundException
-
writeObject
private void writeObject(java.io.ObjectOutputStream stream) throws java.io.IOException
- Throws:
java.io.IOException
-
-
Serialized Fields
-
attributes
java.util.List<AttributeDescriptor<?>> attributes
-
enableCheckpointPartitionMerge
boolean enableCheckpointPartitionMerge
-
endStamp
long endStamp
-
readerFactory
BatchLogReader.Factory<?> readerFactory
-
repositoryFactory
RepositoryFactory repositoryFactory
-
startStamp
long startStamp
-
-
Class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource.Checkpoint extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
partitions
java.util.List<Partition> partitions
-
skipFromFirst
long skipFromFirst
-
-
Class cz.o2.proxima.beam.core.direct.io.DirectBatchUnboundedSource.CheckpointCoder extends org.apache.beam.sdk.coders.Coder<DirectBatchUnboundedSource.Checkpoint> implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.beam.core.direct.io.DirectDataAccessorFactory extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.beam.core.direct.io.DirectDataAccessorWrapper extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
cfg
java.util.Map<java.lang.String,java.lang.Object> cfg
-
context
Context context
-
direct
DataAccessor direct
-
factory
RepositoryFactory factory
-
uri
java.net.URI uri
-
-
Class cz.o2.proxima.beam.core.direct.io.OffsetRestrictionTracker.OffsetRange extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
bounded
boolean bounded
-
consumed
long consumed
-
endOffsetInclusive
Offset endOffsetInclusive
-
extensible
boolean extensible
-
finished
boolean finished
-
partition
Partition partition
-
position
Position position
-
startInclusive
boolean startInclusive
-
startOffset
Offset startOffset
-
totalLimit
long totalLimit
-
-
-
Package cz.o2.proxima.beam.core.io
-
Class cz.o2.proxima.beam.core.io.AttributeDescriptorCoder extends cz.o2.proxima.beam.core.io.AbstractRepositoryCoder<AttributeDescriptor<?>> implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.beam.core.io.EntityDescriptorCoder extends cz.o2.proxima.beam.core.io.AbstractRepositoryCoder<EntityDescriptor> implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.beam.core.io.PairCoder extends org.apache.beam.sdk.coders.CustomCoder<Pair<K,V>> implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.beam.core.io.SchemaStreamElementCoder extends org.apache.beam.sdk.schemas.SchemaCoder<StreamElement> implements Serializable
-
Class cz.o2.proxima.beam.core.io.StreamElementCoder extends org.apache.beam.sdk.coders.CustomCoder<StreamElement> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
repository
RepositoryFactory repository
-
-
-
Package cz.o2.proxima.beam.core.transforms
-
Class cz.o2.proxima.beam.core.transforms.AssignEventTime extends org.apache.beam.sdk.transforms.PTransform<org.apache.beam.sdk.values.PCollection<T>,org.apache.beam.sdk.values.PCollection<T>> implements Serializable
-
Serialized Fields
-
timestampFn
org.apache.beam.sdk.transforms.SerializableFunction<T,org.joda.time.Instant> timestampFn
-
-
-
Class cz.o2.proxima.beam.core.transforms.BufferUntilCheckpoint extends org.apache.beam.sdk.transforms.DoFn<T,T> implements Serializable
-
Class cz.o2.proxima.beam.core.transforms.CalendarWindows.DaysWindows extends org.apache.beam.sdk.transforms.windowing.PartitioningWindowFn<java.lang.Object,org.apache.beam.sdk.transforms.windowing.IntervalWindow> implements Serializable
-
Serialized Fields
-
number
int number
-
startDate
java.time.ZonedDateTime startDate
-
timeZone
java.util.TimeZone timeZone
-
-
-
Class cz.o2.proxima.beam.core.transforms.CalendarWindows.MonthsWindows extends org.apache.beam.sdk.transforms.windowing.PartitioningWindowFn<java.lang.Object,org.apache.beam.sdk.transforms.windowing.IntervalWindow> implements Serializable
-
Serialized Fields
-
dayOfMonth
int dayOfMonth
-
number
int number
-
startDate
java.time.ZonedDateTime startDate
-
timeZone
java.util.TimeZone timeZone
-
-
-
Class cz.o2.proxima.beam.core.transforms.CalendarWindows.YearsWindows extends org.apache.beam.sdk.transforms.windowing.PartitioningWindowFn<java.lang.Object,org.apache.beam.sdk.transforms.windowing.IntervalWindow> implements Serializable
-
Serialized Fields
-
dayOfMonth
int dayOfMonth
-
monthOfYear
int monthOfYear
-
number
int number
-
startDate
java.time.ZonedDateTime startDate
-
timeZone
java.util.TimeZone timeZone
-
-
-
-
Package cz.o2.proxima.beam.io
-
Class cz.o2.proxima.beam.io.ProximaIO.Write extends org.apache.beam.sdk.transforms.PTransform<org.apache.beam.sdk.values.PCollection<StreamElement>,org.apache.beam.sdk.values.PDone> implements Serializable
-
Serialized Fields
-
repositoryFactory
RepositoryFactory repositoryFactory
-
-
-
-
Package cz.o2.proxima.beam.io.pubsub
-
Class cz.o2.proxima.beam.io.pubsub.PubSubDataAccessor extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
entity
EntityDescriptor entity
-
repoFactory
RepositoryFactory repoFactory
-
topic
java.lang.String topic
-
uri
java.net.URI uri
-
-
Class cz.o2.proxima.beam.io.pubsub.PubSubDataAccessorFactory extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package cz.o2.proxima.beam.storage
-
Class cz.o2.proxima.beam.storage.TestStreamStorage extends java.lang.Object implements Serializable
-
Serialized Fields
-
repo
Repository repo
-
-
-
-
Package cz.o2.proxima.beam.tools.groovy
-
Class cz.o2.proxima.beam.tools.groovy.BeamStream.IntegrateDoFn extends org.apache.beam.sdk.transforms.DoFn<org.apache.beam.sdk.values.KV<K,V>,Pair<K,V>> implements Serializable
-
Serialized Fields
-
combiner
BiFunction<V,V,V> combiner
-
initialValue
UnaryFunction<K,V> initialValue
-
stateSpec
org.apache.beam.sdk.state.StateSpec<org.apache.beam.sdk.state.ValueState<V>> stateSpec
-
-
-
Class cz.o2.proxima.beam.tools.groovy.BeamStream.ReduceValueStateByKey extends cz.o2.proxima.beam.tools.groovy.BeamStream.AbstractReduceValueStateByKey<K,V,S,O> implements Serializable
-
Serialized Fields
-
earlyTimer
org.apache.beam.sdk.state.TimerSpec earlyTimer
-
state
org.apache.beam.sdk.state.StateSpec<org.apache.beam.sdk.state.ValueState<Pair<K,S>>> state
-
-
-
Class cz.o2.proxima.beam.tools.groovy.BeamStream.ReduceValueStateByKeyUnsorted extends cz.o2.proxima.beam.tools.groovy.BeamStream.AbstractReduceValueStateByKey<K,V,S,O> implements Serializable
-
Serialized Fields
-
earlyTimer
org.apache.beam.sdk.state.TimerSpec earlyTimer
-
state
org.apache.beam.sdk.state.StateSpec<org.apache.beam.sdk.state.ValueState<Pair<K,S>>> state
-
-
-
Class cz.o2.proxima.beam.tools.groovy.StreamConfig extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
collectHostname
java.lang.String collectHostname
-
collectPort
int collectPort
-
repositoryFactory
RepositoryFactory repositoryFactory
-
-
Class cz.o2.proxima.beam.tools.groovy.TupleCoder extends org.apache.beam.sdk.coders.Coder<groovy.lang.Tuple<java.lang.Object>> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
coder
org.apache.beam.sdk.extensions.kryo.KryoCoder<java.lang.Object> coder
-
hashCode
int hashCode
-
-
-
Package cz.o2.proxima.beam.util.state
-
Class cz.o2.proxima.beam.util.state.ExpandContext.FlushTimerInterceptor extends java.lang.Object implements Serializable
-
Serialized Fields
-
expander
cz.o2.proxima.beam.util.state.FlushTimerParameterExpander expander
-
keyCoder
org.apache.beam.sdk.coders.Coder<K> keyCoder
-
nextFlushInstantFn
UnaryFunction<org.joda.time.Instant,org.joda.time.Instant> nextFlushInstantFn
-
processElementMethod
cz.o2.proxima.beam.util.state.MethodCallUtils.VoidMethodInvoker<java.lang.Object> processElementMethod
-
stateReaders
java.util.LinkedHashMap<java.lang.String,BiFunction<java.lang.Object,byte[],java.lang.Iterable<StateValue>>> stateReaders
-
stateTag
org.apache.beam.sdk.values.TupleTag<StateValue> stateTag
-
-
-
Class cz.o2.proxima.beam.util.state.ExpandContext.OnWindowExpirationInterceptor extends java.lang.Object implements Serializable
-
Serialized Fields
-
expander
cz.o2.proxima.beam.util.state.OnWindowParameterExpander expander
-
onWindowExpiration
@Nullable cz.o2.proxima.beam.util.state.MethodCallUtils.VoidMethodInvoker<? super org.apache.beam.sdk.transforms.DoFn<org.apache.beam.sdk.values.KV<K,V>,?>> onWindowExpiration
-
processElement
cz.o2.proxima.beam.util.state.MethodCallUtils.VoidMethodInvoker<? super org.apache.beam.sdk.transforms.DoFn<org.apache.beam.sdk.values.KV<K,V>,?>> processElement
-
-
-
Class cz.o2.proxima.beam.util.state.ExpandContext.ProcessElementInterceptor extends java.lang.Object implements Serializable
-
Serialized Fields
-
expander
cz.o2.proxima.beam.util.state.ProcessElementParameterExpander expander
-
invoker
cz.o2.proxima.beam.util.state.MethodCallUtils.VoidMethodInvoker<? super org.apache.beam.sdk.transforms.DoFn<org.apache.beam.sdk.values.KV<K,V>,?>> invoker
-
processFn
UnaryFunction<java.lang.Object[],java.lang.Boolean> processFn
-
-
-
Class cz.o2.proxima.beam.util.state.FlushTimerParameterExpander.FlushTimerParameterExpanderImpl extends java.lang.Object implements Serializable
-
Serialized Fields
-
processArgsGenerators
java.util.List<BiFunction<java.lang.Object[],org.apache.beam.sdk.values.TimestampedValue<org.apache.beam.sdk.values.KV<?,?>>,java.lang.Object>> processArgsGenerators
-
-
-
Class cz.o2.proxima.beam.util.state.OnWindowParameterExpander.OnWindowParameterExpanderImpl extends java.lang.Object implements Serializable
-
Serialized Fields
-
processArgsGenerators
java.util.List<BiFunction<java.lang.Object[],org.apache.beam.sdk.values.TimestampedValue<org.apache.beam.sdk.values.KV<?,?>>,java.lang.Object>> processArgsGenerators
-
windowArgsGenerators
java.util.List<BiFunction<java.lang.Object[],org.apache.beam.sdk.values.TimestampedValue<org.apache.beam.sdk.values.KV<?,?>>,java.lang.Object>> windowArgsGenerators
-
-
-
Class cz.o2.proxima.beam.util.state.ProcessElementParameterExpander.ProcessElementParameterExpanderImpl extends java.lang.Object implements Serializable
-
Serialized Fields
-
processArgsGenerators
java.util.List<BiFunction<java.lang.Object[],org.apache.beam.sdk.values.TimestampedValue<org.apache.beam.sdk.values.KV<?,?>>,java.lang.Object>> processArgsGenerators
-
processFn
UnaryFunction<java.lang.Object[],java.lang.Boolean> processFn
-
-
-
Class cz.o2.proxima.beam.util.state.ProcessElementParameterExpander.ProcessFn extends java.lang.Object implements Serializable
-
Serialized Fields
-
elementPos
int elementPos
-
methodParameterCount
int methodParameterCount
-
stateUpdaterMap
java.util.Map<java.lang.String,BiConsumer<java.lang.Object,StateValue>> stateUpdaterMap
-
stateWriteInstant
org.joda.time.Instant stateWriteInstant
-
wrapperArgsKeys
java.util.List<cz.o2.proxima.beam.util.state.TypeId> wrapperArgsKeys
-
-
-
Class cz.o2.proxima.beam.util.state.StateOrInput.StateOrInputCoder extends org.apache.beam.sdk.coders.CustomCoder<StateOrInput<T>> implements Serializable
-
Serialized Fields
-
byteCoder
org.apache.beam.sdk.coders.ByteCoder byteCoder
-
inputCoder
org.apache.beam.sdk.coders.Coder<T> inputCoder
-
stateCoder
StateValue.StateValueCoder stateCoder
-
-
-
Class cz.o2.proxima.beam.util.state.StateValue.StateValueCoder extends org.apache.beam.sdk.coders.CustomCoder<StateValue> implements Serializable
-
-
Package cz.o2.proxima.core.functional
-
Package cz.o2.proxima.core.metrics
-
Class cz.o2.proxima.core.metrics.AbsoluteMetric extends ScalarMetric implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
value
cz.o2.proxima.internal.com.google.common.util.concurrent.AtomicDouble value
-
-
Class cz.o2.proxima.core.metrics.ApproxPercentileMetric extends Metric<Stats> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
current
int current
-
digests
Pair<cz.o2.proxima.internal.com.tdunning.math.stats.TDigest,java.lang.Long>[] digests
-
maxDigests
int maxDigests
-
window
long window
-
-
Class cz.o2.proxima.core.metrics.GaugeMetric extends ScalarMetric implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
value
double value
-
-
Class cz.o2.proxima.core.metrics.Metric extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
group
java.lang.String group
-
name
java.lang.String name
-
-
Class cz.o2.proxima.core.metrics.ScalarMetric extends Metric<java.lang.Double> implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.core.metrics.TimeAveragingMetric extends ScalarMetric implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
checkpointMs
long checkpointMs
-
checkpoints
java.util.NavigableMap<java.lang.Long,java.lang.Double> checkpoints
-
lastCheckpoint
long lastCheckpoint
-
purgeMs
long purgeMs
-
startMs
long startMs
-
sum
double sum
-
sumCheckpoints
double sumCheckpoints
-
windowLengthMs
long windowLengthMs
-
-
-
Package cz.o2.proxima.core.repository
-
Class cz.o2.proxima.core.repository.AttributeDescriptorBase extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
entity
java.lang.String entity
-
name
java.lang.String name
-
proxy
boolean proxy
-
replica
boolean replica
-
schemeUri
java.net.URI schemeUri
-
transactionMode
TransactionMode transactionMode
-
valueSerializer
ValueSerializer<T> valueSerializer
-
wildcard
boolean wildcard
-
-
Class cz.o2.proxima.core.repository.AttributeDescriptorImpl extends AttributeDescriptorBase<T> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
transactionalManagerFamilies
java.util.List<java.lang.String> transactionalManagerFamilies
-
-
Class cz.o2.proxima.core.repository.AttributeFamilyDescriptor extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
access
AccessType access
Access type allowed to this family. -
attributes
java.util.List<AttributeDescriptor<?>> attributes
-
cfg
java.util.Map<java.lang.String,java.lang.Object> cfg
-
entity
EntityDescriptor entity
-
filter
StorageFilter filter
-
name
java.lang.String name
-
replicationConsumerNameFactory
ConsumerNameFactory<AttributeFamilyDescriptor> replicationConsumerNameFactory
-
source
java.lang.String source
-
storageUri
java.net.URI storageUri
-
type
StorageType type
-
-
Class cz.o2.proxima.core.repository.AttributeFamilyProxyDescriptor extends AttributeFamilyDescriptor implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
targetFamilyRead
AttributeFamilyDescriptor targetFamilyRead
-
targetFamilyWrite
AttributeFamilyDescriptor targetFamilyWrite
-
-
Class cz.o2.proxima.core.repository.AttributeProxyDescriptor extends AttributeDescriptorBase<T> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
readTarget
AttributeDescriptor<T> readTarget
-
readTransform
ProxyTransform readTransform
-
writeTarget
AttributeDescriptor<T> writeTarget
-
writeTransform
ProxyTransform writeTransform
-
-
Class cz.o2.proxima.core.repository.ConfigRepository extends Repository implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readObject
private void readObject(java.io.ObjectInputStream ois) throws java.io.IOException, java.lang.ClassNotFoundException
- Throws:
java.io.IOException
java.lang.ClassNotFoundException
-
readResolve
private java.lang.Object readResolve() throws java.io.ObjectStreamException
- Throws:
java.io.ObjectStreamException
-
writeObject
private void writeObject(java.io.ObjectOutputStream oos) throws java.io.IOException
- Throws:
java.io.IOException
-
-
Serialized Fields
-
allCreatedFamilies
java.util.Map<java.lang.String,AttributeFamilyDescriptor> allCreatedFamilies
All families that have been loaded in configuration. -
attributeToFamily
java.util.Map<AttributeDescriptor<?>,java.util.Set<AttributeFamilyDescriptor>> attributeToFamily
Map of attribute descriptor to list of families. This need not be synchronized because it is only written in constructor and then it is read-only. -
config
cz.o2.proxima.typesafe.config.Config config
Application configuration. -
enableCaching
boolean enableCaching
Test repository disables any caching. -
entitiesByName
java.util.Map<java.lang.String,EntityDescriptor> entitiesByName
Map of all entities specified by name. This need not be synchronized because it is only written in constructor and then it is read-only. -
loadClasses
boolean loadClasses
Flag to indicate if we should actually load classes specified in config. This is usually set totrue
, but in case of compiler using the repository, this might be handy to set tofalse
, because the actual classes might not be available yet at the time of the code generation. -
loaderCache
java.util.Map<java.lang.String,java.lang.ClassLoader> loaderCache
Cache of classloader for child modules. -
operators
java.util.Set<DataOperator> operators
Set of operators created by this repository. -
readonly
boolean readonly
When read-only flag is specified, some checks are not performed in construction. This enables to use the repository inside reader applications that don't have to have all the server jars on classpath. -
serializersMap
java.util.Map<java.lang.String,ValueSerializerFactory> serializersMap
Map of all scheme serializers. Key is acceptable scheme of the serializer. This need not be synchronized because it is only written in constructor and then it is read-only. -
transformations
java.util.Map<java.lang.String,TransformationDescriptor> transformations
Map of transformation name to transformation descriptor. -
validateFlags
int validateFlags
Flags to indicate if we should validate perform various validations. Defaults to all validations various validations can be switched off when appropriate.
-
-
Class cz.o2.proxima.core.repository.DefaultConsumerNameFactory.DefaultReplicationConsumerNameFactory extends cz.o2.proxima.core.repository.DefaultConsumerNameFactory<AttributeFamilyDescriptor> implements Serializable
-
Class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
entity
EntityDescriptor entity
-
wrapped
AttributeDescriptor<T> wrapped
-
-
Class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Regular extends EntityAwareAttributeDescriptor<T> implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.core.repository.EntityAwareAttributeDescriptor.Wildcard extends EntityAwareAttributeDescriptor<T> implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.core.repository.EntityDescriptorImpl extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
attributes
java.util.List<AttributeDescriptor<?>> attributes
List of all attribute descriptors. -
attributesByName
java.util.Map<java.lang.String,AttributeDescriptor<?>> attributesByName
Map of attributes by name. -
attributesByPattern
java.util.Map<NamePattern,AttributeDescriptor<?>> attributesByPattern
Map of attributes by pattern. -
name
java.lang.String name
Name of the entity.
-
-
Class cz.o2.proxima.core.repository.Repository extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
factory
RepositoryFactory factory
-
-
Class cz.o2.proxima.core.repository.RepositoryFactory.Compressed extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
compressedConfig
byte[] compressedConfig
-
-
Class cz.o2.proxima.core.repository.RepositoryFactory.LocalInstance extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
factory
RepositoryFactory factory
-
hashCode
int hashCode
-
-
Class cz.o2.proxima.core.repository.RepositoryFactory.VersionedCaching extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
underlying
RepositoryFactory underlying
-
version
long version
-
-
Class cz.o2.proxima.core.repository.TransformationDescriptor extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
attributes
java.util.List<AttributeDescriptor<?>> attributes
List of input attributes of the transformation. -
filter
StorageFilter filter
Input filter. -
inputTransactionMode
TransformationDescriptor.InputTransactionMode inputTransactionMode
-
name
java.lang.String name
Name of the transformation. -
outputTransactionMode
TransformationDescriptor.OutputTransactionMode outputTransactionMode
-
transformation
Transformation transformation
The (stateless) mapping function.
-
-
-
Package cz.o2.proxima.core.scheme
-
Class cz.o2.proxima.core.scheme.AlwaysFailSchemeParser extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.core.scheme.AttributeValueAccessors.ArrayValueAccessorImpl extends java.lang.Object implements Serializable
-
Serialized Fields
-
valueAccessor
AttributeValueAccessor<T,V> valueAccessor
-
-
-
Class cz.o2.proxima.core.scheme.AttributeValueAccessors.PrimitiveValueAccessorImpl extends java.lang.Object implements Serializable
-
Serialized Fields
-
createFromConvertCallback
UnaryFunction<V,T> createFromConvertCallback
-
valueOfConvertCallback
UnaryFunction<T,V> valueOfConvertCallback
-
-
-
Class cz.o2.proxima.core.scheme.BytesSerializer extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.core.scheme.DoubleSerializer extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.core.scheme.FloatSerializer extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.core.scheme.IntSerializer extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.core.scheme.JavaSerializer extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
cache
java.util.Map<java.net.URI,ValueSerializer<?>> cache
-
-
Class cz.o2.proxima.core.scheme.JavaSerializerTest.MyTestObject extends java.lang.Object implements Serializable
- serialVersionUID:
- -8346429941665548558L
-
Serialized Fields
-
key
java.lang.String key
-
value
int value
-
-
Class cz.o2.proxima.core.scheme.JsonSerializer extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.core.scheme.LongSerializer extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.core.scheme.RepositoryInitializedValueSerializer extends java.lang.Object implements Serializable
-
Serialized Fields
-
repo
Repository repo
-
-
-
Class cz.o2.proxima.core.scheme.RepositoryInitializedValueSerializer.Factory extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.core.scheme.SchemaDescriptors.ArrayTypeDescriptor extends java.lang.Object implements Serializable
-
Serialized Fields
-
type
AttributeValueType type
-
valueDescriptor
SchemaDescriptors.SchemaTypeDescriptor<T> valueDescriptor
-
-
-
Class cz.o2.proxima.core.scheme.SchemaDescriptors.EnumTypeDescriptor extends java.lang.Object implements Serializable
-
Serialized Fields
-
type
AttributeValueType type
-
values
java.util.List<java.lang.String> values
-
-
-
Class cz.o2.proxima.core.scheme.SchemaDescriptors.PrimitiveTypeDescriptor extends java.lang.Object implements Serializable
-
Serialized Fields
-
type
AttributeValueType type
-
-
-
Class cz.o2.proxima.core.scheme.SchemaDescriptors.StructureTypeDescriptor extends java.lang.Object implements Serializable
-
Serialized Fields
-
fields
java.util.Map<java.lang.String,SchemaDescriptors.SchemaTypeDescriptor<?>> fields
-
name
java.lang.String name
-
type
AttributeValueType type
-
-
-
Class cz.o2.proxima.core.scheme.SerializationException extends java.lang.RuntimeException implements Serializable
-
Class cz.o2.proxima.core.scheme.StringUtf8Serializer extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package cz.o2.proxima.core.storage
-
Class cz.o2.proxima.core.storage.AbstractStorage.SerializableAbstractStorage extends AbstractStorage implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readObject
private void readObject(java.io.ObjectInputStream ois) throws java.io.IOException, java.lang.ClassNotFoundException
- Throws:
java.io.IOException
java.lang.ClassNotFoundException
-
writeObject
private void writeObject(java.io.ObjectOutputStream oos) throws java.io.IOException
- Throws:
java.io.IOException
-
-
Class cz.o2.proxima.core.storage.Partition.IntegerPartition extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
id
int id
Numerical identifier of the partition.
-
-
Class cz.o2.proxima.core.storage.PassthroughFilter extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.core.storage.StorageFilter.AndFilter extends StorageFilter.CompoundFilter implements Serializable
-
Class cz.o2.proxima.core.storage.StorageFilter.CompoundFilter extends java.lang.Object implements Serializable
-
Serialized Fields
-
filters
java.util.List<StorageFilter> filters
-
-
-
Class cz.o2.proxima.core.storage.StorageFilter.OrFilter extends StorageFilter.CompoundFilter implements Serializable
-
Class cz.o2.proxima.core.storage.StreamElement extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
attribute
java.lang.String attribute
-
attributeDescriptor
AttributeDescriptor<?> attributeDescriptor
-
deleteWildcard
boolean deleteWildcard
-
entityDescriptor
EntityDescriptor entityDescriptor
-
key
java.lang.String key
-
sequentialId
long sequentialId
-
stamp
long stamp
-
uuid
java.lang.String uuid
-
value
byte[] value
-
-
Class cz.o2.proxima.core.storage.ThroughputLimiter.NoOpThroughputLimiter extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package cz.o2.proxima.core.storage.commitlog
-
Class cz.o2.proxima.core.storage.commitlog.FirstPartitionPartitioner extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.core.storage.commitlog.KeyAttributePartitioner extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.core.storage.commitlog.KeyPartitioner extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package cz.o2.proxima.core.storage.internal
-
Class cz.o2.proxima.core.storage.internal.DataAccessorLoader extends java.lang.Object implements Serializable
-
Serialized Fields
-
loaded
java.util.List<T extends AbstractDataAccessorFactory<OP,A>> loaded
-
-
-
-
Package cz.o2.proxima.core.storage.watermark
-
Class cz.o2.proxima.core.storage.watermark.GlobalWatermarkThroughputLimiter extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readResolve
protected java.lang.Object readResolve()
-
-
Serialized Fields
-
closed
boolean closed
-
globalWatermarkUpdatePeriodMs
long globalWatermarkUpdatePeriodMs
-
lastGlobalWatermarkUpdate
long lastGlobalWatermarkUpdate
-
maxAheadTimeFromGlobalMs
long maxAheadTimeFromGlobalMs
-
sleepTimeMs
long sleepTimeMs
-
tracker
GlobalWatermarkTracker tracker
-
-
Class cz.o2.proxima.core.storage.watermark.GlobalWatermarkThroughputLimiterTest.TestTracker extends java.lang.Object implements Serializable
-
Serialized Fields
-
globalWatermark
java.time.Instant globalWatermark
-
testConf
int testConf
-
updates
java.util.Map<java.lang.String,java.lang.Long> updates
-
-
-
-
Package cz.o2.proxima.core.time
-
Class cz.o2.proxima.core.time.AbstractWatermarkEstimator extends java.lang.Object implements Serializable
-
Serialized Fields
-
idlePolicy
WatermarkIdlePolicy idlePolicy
Used idle policy -
isIdle
boolean isIdle
If estimator is in the idle state -
lastWatermark
long lastWatermark
-
-
-
-
Package cz.o2.proxima.core.transaction
-
Class cz.o2.proxima.core.transaction.Commit extends java.lang.Object implements Serializable
-
Serialized Fields
-
outputs
java.util.Collection<StreamElement> outputs
List ofStreamElements
to be replicated. -
transactionUpdates
java.util.Collection<Commit.TransactionUpdate> transactionUpdates
List of possible state updates and/or responses to return to client.
-
-
-
Class cz.o2.proxima.core.transaction.Commit.TransactionUpdate extends java.lang.Object implements Serializable
-
Serialized Fields
-
targetFamily
java.lang.String targetFamily
Name of target attribute family. -
update
StreamElement update
The update itself.
-
-
-
Class cz.o2.proxima.core.transaction.KeyAttribute extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
attributeDescriptor
AttributeDescriptor<?> attributeDescriptor
-
attributeSuffix
java.lang.String attributeSuffix
-
delete
boolean delete
-
entity
EntityDescriptor entity
-
key
java.lang.String key
-
sequentialId
long sequentialId
-
-
Class cz.o2.proxima.core.transaction.Request extends java.lang.Object implements Serializable
-
Serialized Fields
-
flags
Request.Flags flags
-
inputAttributes
java.util.List<KeyAttribute> inputAttributes
-
outputs
java.util.Collection<StreamElement> outputs
-
responsePartitionId
int responsePartitionId
-
-
-
Class cz.o2.proxima.core.transaction.Response extends java.lang.Object implements Serializable
-
Serialized Fields
-
flags
Response.Flags flags
-
seqId
long seqId
A sequence ID assigned to the transaction by the transaction manager. Note that this field will be filled if the flag is set toResponse.Flags.OPEN
. All writes that happen after successful commit MUST have this sequence ID in theStreamElement.upsert(cz.o2.proxima.core.repository.EntityDescriptor, cz.o2.proxima.core.repository.AttributeDescriptor<?>, java.lang.String, java.lang.String, java.lang.String, long, byte[])
orStreamElement.delete(cz.o2.proxima.core.repository.EntityDescriptor, cz.o2.proxima.core.repository.AttributeDescriptor<?>, java.lang.String, java.lang.String, java.lang.String, long)
filled. -
stamp
long stamp
A timestamp that *must* be used as a timestamp of all writes after the commit. -
targetPartitionId
int targetPartitionId
This is a transient identifier, we don't need to serialize it, just needs to be there, when sending response, so that it gets written to the correct partition.
-
-
-
Class cz.o2.proxima.core.transaction.State extends java.lang.Object implements Serializable
-
Serialized Fields
-
committedOutputs
java.util.Collection<StreamElement> committedOutputs
-
flags
State.Flags flags
-
inputAttributes
java.util.Collection<KeyAttribute> inputAttributes
-
sequentialId
long sequentialId
-
stamp
long stamp
-
-
-
Class cz.o2.proxima.core.transaction.TransactionPartitioner extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package cz.o2.proxima.core.transform
-
Class cz.o2.proxima.core.transform.DummyDataRename extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.core.transform.EventDataToDummy extends java.lang.Object implements Serializable
-
Serialized Fields
-
prefix
java.lang.String prefix
-
target
EntityDescriptor target
-
targetAttr
AttributeDescriptor targetAttr
-
-
-
Class cz.o2.proxima.core.transform.EventRename extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.core.transform.EventToDummy2 extends java.lang.Object implements Serializable
-
Serialized Fields
-
dummy2
EntityDescriptor dummy2
-
event
AttributeDescriptor<?> event
-
-
-
Class cz.o2.proxima.core.transform.EventTransform extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.core.transform.IdentityTransformation extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.core.transform.OperatorSpecificTransformationTest.Proxy extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.core.transform.OperatorSpecificTransformationTest.Transformation extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.core.transform.ReadProxy extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.core.transform.RenameTransformation extends java.lang.Object implements Serializable
-
Serialized Fields
-
descTransform
UnaryFunction<AttributeDescriptor<?>,AttributeDescriptor<?>> descTransform
-
nameTransform
BiFunction<java.lang.String,AttributeDescriptor<?>,java.lang.String> nameTransform
-
-
-
Class cz.o2.proxima.core.transform.UserGatewayIndex extends java.lang.Object implements Serializable
-
Serialized Fields
-
gateway
EntityDescriptor gateway
-
gatewayUsers
EntityAwareAttributeDescriptor.Wildcard<byte[]> gatewayUsers
-
user
EntityDescriptor user
-
userGateways
EntityAwareAttributeDescriptor.Wildcard<byte[]> userGateways
-
-
-
Class cz.o2.proxima.core.transform.WildcardRename extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.core.transform.WriteProxy extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
target
java.lang.String target
-
-
-
Package cz.o2.proxima.core.util
-
Class cz.o2.proxima.core.util.DummyFilter extends PassthroughFilter implements Serializable
-
Serialized Fields
-
setupCalled
boolean setupCalled
-
-
-
Class cz.o2.proxima.core.util.NamePattern extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
pattern
java.lang.String pattern
-
prefixOnly
boolean prefixOnly
-
-
Class cz.o2.proxima.core.util.Pair extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.core.util.SerializableCountDownLatch extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.core.util.SerializableLong extends java.lang.Object implements Serializable
-
Serialized Fields
-
uuid
java.lang.String uuid
-
-
-
Class cz.o2.proxima.core.util.SerializableScopedValue extends java.lang.Object implements Serializable
-
-
Package cz.o2.proxima.core.utils.zookeeper
-
Class cz.o2.proxima.core.utils.zookeeper.ZKGlobalWatermarkTracker extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readResolve
protected java.lang.Object readResolve()
-
-
Serialized Fields
-
maxAcceptableUpdateMs
long maxAcceptableUpdateMs
-
parentNode
java.lang.String parentNode
-
sessionTimeout
int sessionTimeout
-
timeProvider
TimeProvider timeProvider
-
trackerName
java.lang.String trackerName
-
zkConnectString
java.lang.String zkConnectString
-
-
-
Package cz.o2.proxima.direct.core
-
Class cz.o2.proxima.direct.core.Context extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
executorFactory
Factory<java.util.concurrent.ExecutorService> executorFactory
Executor associated with all asynchronous operations. -
resolver
UnaryFunction<AttributeFamilyDescriptor,DirectAttributeFamilyDescriptor> resolver
Resolver of proxima core's attribute family to direct representation.
-
-
Class cz.o2.proxima.direct.core.DirectAttributeFamilyDescriptor extends java.lang.Object implements Serializable
- serialVersionUID:
- 2L
-
Serialized Fields
-
batchReaderFactory
BatchLogReader.Factory<?> batchReaderFactory
-
cachedViewFactory
CachedView.Factory cachedViewFactory
-
commitLogReaderFactory
CommitLogReader.Factory<?> commitLogReaderFactory
-
desc
AttributeFamilyDescriptor desc
-
randomAccessReaderFactory
RandomAccessReader.Factory<?> randomAccessReaderFactory
-
repositoryFactory
RepositoryFactory repositoryFactory
-
writerFactory
AttributeWriterBase.Factory<?> writerFactory
-
-
Class cz.o2.proxima.direct.core.DirectAttributeFamilyProxyDescriptor extends DirectAttributeFamilyDescriptor implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.direct.core.DirectDataOperator.DelegateDataAccessorFactory extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
delegate
DataAccessorFactory delegate
-
-
Class cz.o2.proxima.direct.core.StdoutStorage extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package cz.o2.proxima.direct.core.batch
-
Class cz.o2.proxima.direct.core.batch.BoundedPartition extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
id
int id
-
size
long size
-
-
Class cz.o2.proxima.direct.core.batch.Offset.SimpleOffset extends java.lang.Object implements Serializable
-
Serialized Fields
-
elementIndex
long elementIndex
-
last
boolean last
-
partition
Partition partition
-
-
-
-
Package cz.o2.proxima.direct.core.commitlog
-
Package cz.o2.proxima.direct.core.randomaccess
-
Class cz.o2.proxima.direct.core.randomaccess.KeyValue extends StreamElement implements Serializable
-
Serialized Fields
-
offset
RandomOffset offset
-
-
-
Class cz.o2.proxima.direct.core.randomaccess.MultiAccessBuilder extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
attrMapToFactory
java.util.Map<AttributeDescriptor<?>,RandomAccessReader.Factory<?>> attrMapToFactory
-
context
Context context
-
-
Class cz.o2.proxima.direct.core.randomaccess.RawOffset extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
offset
java.lang.String offset
-
-
-
Package cz.o2.proxima.direct.core.time
-
Class cz.o2.proxima.direct.core.time.BoundedOutOfOrdernessWatermarkEstimator extends AbstractWatermarkEstimator implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
maxOutOfOrderness
long maxOutOfOrderness
-
maxTimestamp
java.lang.Long maxTimestamp
-
minWatermark
long minWatermark
-
-
Class cz.o2.proxima.direct.core.time.BoundedOutOfOrdernessWatermarkEstimator.Factory extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
idlePolicyFactory
WatermarkIdlePolicyFactory idlePolicyFactory
-
maxOutOfOrderness
long maxOutOfOrderness
-
-
Class cz.o2.proxima.direct.core.time.MinimalPartitionWatermarkEstimator extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
estimators
java.util.concurrent.ConcurrentHashMap<java.lang.Integer,WatermarkEstimator> estimators
-
-
Class cz.o2.proxima.direct.core.time.NotProgressingWatermarkIdlePolicy extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
watermark
long watermark
-
-
Class cz.o2.proxima.direct.core.time.NotProgressingWatermarkIdlePolicy.Factory extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.direct.core.time.ProcessingTimeShiftingWatermarkIdlePolicy extends java.lang.Object implements Serializable
-
Serialized Fields
-
lastIdleProcessingTime
long lastIdleProcessingTime
-
lastIdleWatermark
long lastIdleWatermark
-
timeFactory
Factory<java.lang.Long> timeFactory
-
-
-
Class cz.o2.proxima.direct.core.time.ProcessingTimeShiftingWatermarkIdlePolicy.Factory extends java.lang.Object implements Serializable
-
Serialized Fields
-
timeFactory
Factory<java.lang.Long> timeFactory
-
-
-
Class cz.o2.proxima.direct.core.time.ProcessingTimeShiftingWatermarkIdlePolicyTest.TimeFactory extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.direct.core.time.ProcessingTimeWatermarkEstimator extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
minWatermark
long minWatermark
-
timestampSupplier
TimestampSupplier timestampSupplier
-
-
Class cz.o2.proxima.direct.core.time.ProcessingTimeWatermarkEstimator.Factory extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.direct.core.time.SkewedProcessingTimeIdlePolicy extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
currentWatermark
long currentWatermark
-
timestampSkew
long timestampSkew
-
timestampSupplier
TimestampSupplier timestampSupplier
-
-
Class cz.o2.proxima.direct.core.time.SkewedProcessingTimeIdlePolicy.Factory extends java.lang.Object implements Serializable
-
Serialized Fields
-
timestampSkew
long timestampSkew
-
-
-
Class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator extends AbstractWatermarkEstimator implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
allowedTimestampSkew
long allowedTimestampSkew
-
estimateDurationMs
long estimateDurationMs
-
lastRotate
java.util.concurrent.atomic.AtomicLong lastRotate
-
lastStatLogged
java.util.concurrent.atomic.AtomicLong lastStatLogged
-
rotatesToInitialize
java.util.concurrent.atomic.AtomicInteger rotatesToInitialize
-
stepDiffs
long[] stepDiffs
-
stepMs
long stepMs
-
timestampSupplier
TimestampSupplier timestampSupplier
-
watermark
java.util.concurrent.atomic.AtomicLong watermark
-
-
Class cz.o2.proxima.direct.core.time.UnboundedOutOfOrdernessWatermarkEstimator.Factory extends java.lang.Object implements Serializable
-
Serialized Fields
-
allowedTimestampSkew
long allowedTimestampSkew
-
durationMs
long durationMs
-
idlePolicyFactory
WatermarkIdlePolicyFactory idlePolicyFactory
-
minWatermark
long minWatermark
-
stepMs
long stepMs
-
-
-
Class cz.o2.proxima.direct.core.time.WatermarkConfiguration extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
cfg
java.util.Map<java.lang.String,java.lang.Object> cfg
-
watermarkEstimatorFactory
WatermarkEstimatorFactory watermarkEstimatorFactory
-
watermarkIdlePolicyFactory
WatermarkIdlePolicyFactory watermarkIdlePolicyFactory
-
-
Class cz.o2.proxima.direct.core.time.WatermarkConfigurationTest.CustomIdlePolicyFactory extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.direct.core.time.WatermarkConfigurationTest.CustomWatermarkConfiguration.Estimator extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.direct.core.time.WatermarkConfigurationTest.CustomWatermarkConfiguration.IdlePolicy extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.direct.core.time.WatermarkConfigurationTest.CustomWatermarkEstimatorFactory extends java.lang.Object implements Serializable
-
-
Package cz.o2.proxima.direct.core.transaction
-
Class cz.o2.proxima.direct.core.transaction.ServerTransactionManager.InitialSequenceIdPolicy.Default extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.TransactionPreconditionFailedException extends java.lang.RuntimeException implements Serializable
-
Class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.TransactionRejectedException extends java.lang.Exception implements Serializable
-
Serialized Fields
-
responseFlags
Response.Flags responseFlags
-
transactionId
java.lang.String transactionId
-
-
-
Class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.TransactionRejectedRuntimeException extends java.lang.RuntimeException implements Serializable
-
Class cz.o2.proxima.direct.core.transaction.TransactionalOnlineAttributeWriter.TransactionValidator extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.direct.core.transaction.TransactionCommitTransformation extends java.lang.Object implements Serializable
-
Serialized Fields
-
commitDesc
EntityAwareAttributeDescriptor.Regular<Commit> commitDesc
-
repositoryFactory
RepositoryFactory repositoryFactory
-
writers
java.util.Map<java.lang.String,OnlineAttributeWriter> writers
-
-
-
Class cz.o2.proxima.direct.core.transaction.TransactionUniqueConstraintValidator extends TransactionalOnlineAttributeWriter.TransactionValidator implements Serializable
-
Serialized Fields
-
gateway
EntityDescriptor gateway
-
intField
EntityAwareAttributeDescriptor.Regular<java.lang.Integer> intField
-
op
DirectDataOperator op
-
reader
RandomAccessReader reader
-
-
-
-
Package cz.o2.proxima.direct.core.transform
-
Package cz.o2.proxima.direct.core.view
-
Package cz.o2.proxima.direct.io.bigtable
-
Class cz.o2.proxima.direct.io.bigtable.BigTableStorage extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package cz.o2.proxima.direct.io.blob
-
Class cz.o2.proxima.direct.io.blob.BlobPath extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
blob
BlobT extends BlobBase blob
-
fs
FileSystem fs
-
-
Class cz.o2.proxima.direct.io.blob.BlobStorageAccessor extends AbstractStorage.SerializableAbstractStorage implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
cfg
java.util.Map<java.lang.String,java.lang.Object> cfg
-
familyDescriptor
AttributeFamilyDescriptor familyDescriptor
-
-
Class cz.o2.proxima.direct.io.blob.RetryStrategy extends java.lang.Object implements Serializable
-
Serialized Fields
-
initialRetryDelay
int initialRetryDelay
-
maxRetryDelay
int maxRetryDelay
-
retryableException
java.util.Set<java.lang.Class<? extends java.lang.Exception>> retryableException
-
-
-
-
Package cz.o2.proxima.direct.io.bulkfs
-
Class cz.o2.proxima.direct.io.bulkfs.AbstractBulkFileSystemAttributeWriterTest extends java.lang.Object implements Serializable
-
Serialized Fields
-
attr
AttributeDescriptor<?> attr
-
direct
DirectDataOperator direct
-
entity
EntityDescriptor entity
-
flushedPaths
java.util.Set<java.lang.String> flushedPaths
-
onFlush
java.util.concurrent.atomic.AtomicReference<java.lang.Throwable> onFlush
-
params
cz.o2.proxima.direct.io.bulkfs.AbstractBulkFileSystemAttributeWriterTest.Params params
-
repo
Repository repo
-
tempFolder
org.junit.rules.TemporaryFolder tempFolder
-
uri
java.net.URI uri
-
wildcard
AttributeDescriptor<?> wildcard
-
writer
AbstractBulkFileSystemAttributeWriter writer
-
written
java.util.Map<java.lang.Long,java.util.List<StreamElement>> written
-
-
-
Class cz.o2.proxima.direct.io.bulkfs.AbstractBulkFileSystemAttributeWriterTest.InstantiableJsonFormat extends JsonFormat implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.direct.io.bulkfs.ComplexWriteTest extends java.lang.Object implements Serializable
-
Serialized Fields
-
allowedLateness
long allowedLateness
-
attr
AttributeDescriptor<?> attr
-
direct
DirectDataOperator direct
-
entity
EntityDescriptor entity
-
flushed
java.util.concurrent.atomic.AtomicInteger flushed
-
repo
Repository repo
-
rollPeriod
long rollPeriod
-
tempFolder
org.junit.rules.TemporaryFolder tempFolder
-
uri
java.net.URI uri
-
wildcard
AttributeDescriptor<?> wildcard
-
writer
AbstractBulkFileSystemAttributeWriter writer
-
-
-
Class cz.o2.proxima.direct.io.bulkfs.DefaultNamingConvention extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
prefix
java.lang.String prefix
-
rollPeriodMs
long rollPeriodMs
-
suffix
java.lang.String suffix
-
uuidGenerator
Factory<java.lang.String> uuidGenerator
-
-
Class cz.o2.proxima.direct.io.bulkfs.DefaultNamingConventionFactory extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.direct.io.bulkfs.FileFormatUtilsTest.DummyNamingConvention extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.direct.io.bulkfs.FileFormatUtilsTest.DummyNamingConventionFactory extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.direct.io.bulkfs.JsonFormat extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
gzip
boolean gzip
-
-
Class cz.o2.proxima.direct.io.bulkfs.LocalPath extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
fs
FileSystem fs
-
path
java.io.File path
-
-
-
Package cz.o2.proxima.direct.io.bulkfs.parquet
-
Class cz.o2.proxima.direct.io.bulkfs.parquet.ParquetFileFormat extends java.lang.Object implements Serializable
-
-
Package cz.o2.proxima.direct.io.cassandra
-
Class cz.o2.proxima.direct.io.cassandra.CacheableCqlFactory extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
deleteCache
java.util.Map<AttributeDescriptor<?>,com.datastax.driver.core.PreparedStatement> deleteCache
-
deleteWildcardCache
java.util.Map<AttributeDescriptor<?>,com.datastax.driver.core.PreparedStatement> deleteWildcardCache
-
entity
EntityDescriptor entity
-
getCache
java.util.Map<AttributeDescriptor<?>,com.datastax.driver.core.PreparedStatement> getCache
-
ingestCache
java.util.Map<AttributeDescriptor<?>,com.datastax.driver.core.PreparedStatement> ingestCache
-
listCache
java.util.Map<AttributeDescriptor<?>,com.datastax.driver.core.PreparedStatement> listCache
-
payloadCol
java.lang.String payloadCol
-
tableName
java.lang.String tableName
-
ttl
long ttl
A TTL value in seconds associated with each update or insert.
-
-
Class cz.o2.proxima.direct.io.cassandra.CassandraDBAccessor extends AbstractStorage.SerializableAbstractStorage implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readResolve
java.lang.Object readResolve() throws java.io.ObjectStreamException
- Throws:
java.io.ObjectStreamException
-
-
Serialized Fields
-
batchParallelism
int batchParallelism
Parallel scans. -
consistencyLevel
com.datastax.driver.core.ConsistencyLevel consistencyLevel
Quorum for both reads and writes. -
converter
StringConverter<?> converter
Converter between string and native cassandra type used for wildcard types. -
cqlFactoryName
java.lang.String cqlFactoryName
-
password
java.lang.String password
-
username
java.lang.String username
-
-
Class cz.o2.proxima.direct.io.cassandra.CassandraPartition extends BoundedPartition implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
endInclusive
boolean endInclusive
-
maxStamp
long maxStamp
-
minStamp
long minStamp
-
tokenEnd
long tokenEnd
-
tokenStart
long tokenStart
-
-
Class cz.o2.proxima.direct.io.cassandra.CassandraStorageDescriptor extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.direct.io.cassandra.DateToLongConverter extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.direct.io.cassandra.DefaultCqlFactory extends CacheableCqlFactory implements Serializable
-
Serialized Fields
-
converter
StringConverter<?> converter
Converter between type stored in cassandra and string used as a specifier in wildcard attributes. -
primaryField
java.lang.String primaryField
The name of the field used as primary key or first part of composite primary key. -
reversed
boolean reversed
true
if the secondary key sorting reversed (DESC). -
secondaryField
java.lang.String secondaryField
An optional name of secondary field for composite key. If missing, name of the attribute (without .*) is used. -
serializer
cz.o2.proxima.direct.io.cassandra.DefaultCqlFactory.Serializer serializer
Serializer ofStreamElement
to cell and back.
-
-
-
Class cz.o2.proxima.direct.io.cassandra.Offsets.Raw extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
str
java.lang.String str
-
-
Class cz.o2.proxima.direct.io.cassandra.Offsets.Token extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
tkn
long tkn
-
-
Class cz.o2.proxima.direct.io.cassandra.StringConverter.DefaultConverter extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.direct.io.cassandra.TransformingCqlFactory extends CacheableCqlFactory implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
columns
java.util.List<java.lang.String> columns
Name of the the primary key column . -
extractors
java.util.List<UnaryFunction<Pair<java.lang.String,T extends java.io.Serializable>,java.lang.Object>> extractors
Extract name value of key from ingest. -
filter
UnaryFunction<T extends java.io.Serializable,java.lang.Boolean> filter
Filter for bad messages. -
parser
UnaryFunction<StreamElement,T extends java.io.Serializable> parser
Parser of ingest to any intermediate type.
-
-
-
Package cz.o2.proxima.direct.io.elasticsearch
-
Class cz.o2.proxima.direct.io.elasticsearch.DocumentFormatter.Default extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchAccessor extends AbstractStorage.SerializableAbstractStorage implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
batchSize
int batchSize
-
bulkSizeMb
int bulkSizeMb
-
cfg
java.util.Map<java.lang.String,java.lang.Object> cfg
-
concurrentRequests
int concurrentRequests
-
connectionRequestTimeoutMs
int connectionRequestTimeoutMs
-
connectTimeoutMs
int connectTimeoutMs
-
documentFormatter
DocumentFormatter documentFormatter
-
flushIntervalMs
int flushIntervalMs
-
indexName
java.lang.String indexName
-
keystorePassword
java.lang.String keystorePassword
-
keystorePath
java.lang.String keystorePath
-
keystoreType
java.lang.String keystoreType
-
scheme
java.lang.String scheme
-
socketTimeoutMs
int socketTimeoutMs
-
truststorePassword
java.lang.String truststorePassword
-
truststorePath
java.lang.String truststorePath
-
-
Class cz.o2.proxima.direct.io.elasticsearch.ElasticsearchStorage extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package cz.o2.proxima.direct.io.gcloud.storage
-
Class cz.o2.proxima.direct.io.gcloud.storage.GCloudBlobPath extends BlobPath<GCloudBlobPath.GCloudBlob> implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.direct.io.gcloud.storage.GCloudBlobPath.GCloudBlob extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
blob
com.google.cloud.storage.Blob blob
-
-
Class cz.o2.proxima.direct.io.gcloud.storage.GCloudFileSystem extends cz.o2.proxima.direct.io.gcloud.storage.GCloudClient implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
namingConvention
NamingConvention namingConvention
-
uri
java.net.URI uri
-
-
Class cz.o2.proxima.direct.io.gcloud.storage.GCloudStorageDescriptor extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package cz.o2.proxima.direct.io.hadoop
-
Class cz.o2.proxima.direct.io.hadoop.HadoopDataAccessor extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
allowedLateness
long allowedLateness
-
batchProcessSize
long batchProcessSize
-
cfg
java.util.Map<java.lang.String,java.lang.Object> cfg
-
entityDesc
EntityDescriptor entityDesc
-
format
FileFormat format
-
hadoopFs
cz.o2.proxima.direct.io.hadoop.HadoopFileSystem hadoopFs
-
namingConvention
NamingConvention namingConvention
-
rollInterval
long rollInterval
-
temporaryHadoopFs
cz.o2.proxima.direct.io.hadoop.HadoopFileSystem temporaryHadoopFs
-
temporaryNamingConvention
NamingConvention temporaryNamingConvention
-
uri
java.net.URI uri
-
-
Class cz.o2.proxima.direct.io.hadoop.HadoopPartition extends BoundedPartition implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
paths
java.util.List<cz.o2.proxima.direct.io.hadoop.HadoopPath> paths
-
size
long size
-
-
Class cz.o2.proxima.direct.io.hadoop.HadoopStorage extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package cz.o2.proxima.direct.io.hbase
-
Class cz.o2.proxima.direct.io.hbase.HBaseDataAccessor extends AbstractStorage.SerializableAbstractStorage implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
cfg
java.util.Map<java.lang.String,java.lang.Object> cfg
-
confFactory
HBaseDataAccessor.ConfFactory confFactory
-
-
Class cz.o2.proxima.direct.io.hbase.HBaseStorageDescriptor extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package cz.o2.proxima.direct.io.http
-
Class cz.o2.proxima.direct.io.http.HttpAccessor extends AbstractStorage.SerializableAbstractStorage implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
cfg
java.util.Map<java.lang.String,java.lang.Object> cfg
-
-
Class cz.o2.proxima.direct.io.http.HttpStorage extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.direct.io.http.HttpWriter extends AbstractStorage implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
cfg
java.util.Map<java.lang.String,java.lang.Object> cfg
-
connFactory
ConnFactory connFactory
-
-
Class cz.o2.proxima.direct.io.http.TestableConnFactory extends java.lang.Object implements Serializable
-
-
Package cz.o2.proxima.direct.io.http.opentsdb
-
Class cz.o2.proxima.direct.io.http.opentsdb.OpenTsdbConnectionFactory extends TestableConnFactory implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.direct.io.http.opentsdb.OpenTsdbWriter extends HttpWriter implements Serializable
- serialVersionUID:
- 1L
-
-
Package cz.o2.proxima.direct.io.kafka
-
Class cz.o2.proxima.direct.io.kafka.ConsumerGroup extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
assignments
java.util.NavigableMap<java.lang.Integer,cz.o2.proxima.direct.io.kafka.ConsumerGroup.Assignment> assignments
-
autoRelalance
boolean autoRelalance
-
name
java.lang.String name
-
numPartitions
int numPartitions
-
topic
java.lang.String topic
-
-
Class cz.o2.proxima.direct.io.kafka.KafkaAccessor extends AbstractStorage.SerializableAbstractStorage implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
assignmentTimeoutMillis
long assignmentTimeoutMillis
-
autoCommitIntervalMs
long autoCommitIntervalMs
-
cfg
java.util.Map<java.lang.String,java.lang.Object> cfg
-
consumerPollInterval
long consumerPollInterval
-
logStaleCommitIntervalMs
long logStaleCommitIntervalMs
-
maxBytesPerSec
long maxBytesPerSec
-
maxPollRecords
int maxPollRecords
-
partitioner
Partitioner partitioner
-
serializerClass
java.lang.Class<ElementSerializer<?,?>> serializerClass
-
topic
java.lang.String topic
-
topicPattern
java.lang.String topicPattern
-
watermarkConfiguration
KafkaWatermarkConfiguration watermarkConfiguration
-
-
Class cz.o2.proxima.direct.io.kafka.KafkaAccessorTest extends java.lang.Object implements Serializable
-
Serialized Fields
-
accessType
AccessType accessType
-
adminClient
cz.o2.proxima.kafka.shaded.org.apache.kafka.clients.admin.AdminClient adminClient
-
attrFmlDesc
AttributeFamilyDescriptor attrFmlDesc
-
cfgEtrs
java.util.List<cz.o2.proxima.kafka.shaded.org.apache.kafka.clients.admin.ConfigEntry> cfgEtrs
-
cfgs
java.util.List<cz.o2.proxima.kafka.shaded.org.apache.kafka.clients.admin.Config> cfgs
-
direct
DirectDataOperator direct
-
kafkaAccessor
KafkaAccessor kafkaAccessor
-
repo
Repository repo
-
-
-
Class cz.o2.proxima.direct.io.kafka.KafkaStorage extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.direct.io.kafka.KafkaStreamElement extends StreamElement implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
offset
long offset
Offset in the partition. -
partition
int partition
Partition in Kafka this element comes from.
-
-
Class cz.o2.proxima.direct.io.kafka.KafkaStreamElement.KafkaStreamElementSerializer extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.direct.io.kafka.KafkaWatermarkConfiguration extends WatermarkConfiguration implements Serializable
-
Class cz.o2.proxima.direct.io.kafka.LocalKafkaCommitLogDescriptor extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
accessorModifier
java.util.function.Function<cz.o2.proxima.direct.io.kafka.LocalKafkaCommitLogDescriptor.Accessor,cz.o2.proxima.direct.io.kafka.LocalKafkaCommitLogDescriptor.Accessor> accessorModifier
-
id
java.lang.String id
-
-
Class cz.o2.proxima.direct.io.kafka.LocalKafkaCommitLogDescriptor.Accessor extends KafkaAccessor implements Serializable
- serialVersionUID:
- 1L
-
Serialization Methods
-
readObject
private void readObject(java.io.ObjectInputStream arg0) throws java.lang.ClassNotFoundException, java.io.IOException
- Throws:
java.lang.ClassNotFoundException
java.io.IOException
-
writeObject
private void writeObject(java.io.ObjectOutputStream arg0) throws java.io.IOException
- Throws:
java.io.IOException
-
-
Serialized Fields
-
descriptorId
java.lang.String descriptorId
-
numPartitions
int numPartitions
-
perPartitionRetention
long perPartitionRetention
-
-
Class cz.o2.proxima.direct.io.kafka.LocalKafkaCommitLogDescriptorTest extends java.lang.Object implements Serializable
-
Serialized Fields
-
attr
AttributeDescriptorBase<byte[]> attr
-
attrWildcard
AttributeDescriptorBase<byte[]> attrWildcard
-
direct
DirectDataOperator direct
-
entity
EntityDescriptor entity
-
kafka
cz.o2.proxima.direct.io.kafka.LocalKafkaCommitLogDescriptor kafka
-
storageUri
java.net.URI storageUri
-
strAttr
AttributeDescriptorBase<java.lang.String> strAttr
-
topic
java.lang.String topic
-
-
-
Class cz.o2.proxima.direct.io.kafka.LocalKafkaCommitLogDescriptorTest.FirstBytePartitioner extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.direct.io.kafka.LocalKafkaCommitLogDescriptorTest.FixedWatermarkEstimatorFactory extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.direct.io.kafka.LocalKafkaCommitLogDescriptorTest.FixedWatermarkIdlePolicyFactory extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.direct.io.kafka.LocalKafkaCommitLogDescriptorTest.SingleAttrSerializer extends java.lang.Object implements Serializable
-
Serialized Fields
-
attrDesc
AttributeDescriptor<?> attrDesc
-
-
-
-
Package cz.o2.proxima.direct.io.kafka.serializer
-
Class cz.o2.proxima.direct.io.kafka.serializer.ValueAsBytesSerializer extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
attr
AttributeDescriptor<byte[]> attr
-
readAttributeFn
UnaryFunction<EntityDescriptor,AttributeDescriptor<byte[]>> readAttributeFn
-
-
Class cz.o2.proxima.direct.io.kafka.serializer.ValueAsStringSerializer extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
attr
AttributeDescriptor<java.lang.String> attr
-
readAttributeFn
UnaryFunction<EntityDescriptor,AttributeDescriptor<java.lang.String>> readAttributeFn
-
-
-
Package cz.o2.proxima.direct.io.pubsub
-
Class cz.o2.proxima.direct.io.pubsub.PubSubAccessor extends AbstractStorage.SerializableAbstractStorage implements Serializable
- serialVersionUID:
- 2L
-
Serialized Fields
-
bulk
cz.o2.proxima.direct.io.pubsub.PubSubAccessor.BulkConfig bulk
-
cfg
java.util.Map<java.lang.String,java.lang.Object> cfg
-
maxAckDeadline
int maxAckDeadline
-
project
java.lang.String project
-
subscriptionAckDeadline
int subscriptionAckDeadline
-
subscriptionAutoCreate
boolean subscriptionAutoCreate
-
topic
java.lang.String topic
-
watermarkConfiguration
PubSubWatermarkConfiguration watermarkConfiguration
-
-
Class cz.o2.proxima.direct.io.pubsub.PubSubStorage extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
defaultAllowedTimestampSkew
long defaultAllowedTimestampSkew
-
defaultMaxAckDeadlineMs
long defaultMaxAckDeadlineMs
-
defaultSubscriptionAckDeadlineSeconds
int defaultSubscriptionAckDeadlineSeconds
-
defaultSubscriptionAutoCreate
boolean defaultSubscriptionAutoCreate
-
defaultWatermarkEstimateDuration
java.lang.Integer defaultWatermarkEstimateDuration
-
-
Class cz.o2.proxima.direct.io.pubsub.PubSubWatermarkConfiguration extends WatermarkConfiguration implements Serializable
-
Serialized Fields
-
defaultAllowedTimestampSkew
long defaultAllowedTimestampSkew
-
defaultEstimateDuration
long defaultEstimateDuration
-
-
-
-
Package cz.o2.proxima.direct.io.s3
-
Class cz.o2.proxima.direct.io.s3.S3BlobPath extends BlobPath<S3BlobPath.S3Blob> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
context
Context context
-
-
Class cz.o2.proxima.direct.io.s3.S3BlobPath.S3Blob extends java.lang.Object implements Serializable
-
Serialized Fields
-
fs
S3FileSystem fs
-
name
java.lang.String name
-
size
long size
-
-
-
Class cz.o2.proxima.direct.io.s3.S3FileSystem extends cz.o2.proxima.direct.io.s3.S3Client implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
context
Context context
-
namingConvention
NamingConvention namingConvention
-
uri
java.net.URI uri
-
-
Class cz.o2.proxima.direct.io.s3.S3StorageDescriptor extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package cz.o2.proxima.direct.jdbc
-
Class cz.o2.proxima.direct.jdbc.JdbcDataAccessor extends AbstractStorage.SerializableAbstractStorage implements Serializable
-
Serialized Fields
-
jdbcDriver
java.lang.String jdbcDriver
-
jdbcPassword
java.lang.String jdbcPassword
-
jdbcUri
java.lang.String jdbcUri
-
jdbcUsername
java.lang.String jdbcUsername
-
numSourceBorrows
int numSourceBorrows
-
resultConverter
Converter<?> resultConverter
-
sqlStatementFactory
SqlStatementFactory sqlStatementFactory
-
-
-
Class cz.o2.proxima.direct.jdbc.JdbcStorageDescriptor extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.direct.jdbc.Offsets.Raw extends java.lang.Object implements Serializable
-
Serialized Fields
-
key
java.lang.String key
-
-
-
Class cz.o2.proxima.direct.jdbc.RowAsJsonConverter extends java.lang.Object implements Serializable
-
Class cz.o2.proxima.direct.jdbc.RowAsJsonLogReaderStatementFactory extends java.lang.Object implements Serializable
-
Serialized Fields
-
tableName
java.lang.String tableName
-
-
-
-
Package cz.o2.proxima.flink.core
-
Class cz.o2.proxima.flink.core.BatchLogSourceFunction extends cz.o2.proxima.flink.core.AbstractLogSourceFunction<BatchLogReader,cz.o2.proxima.flink.core.BatchLogSourceFunction.LogObserver<OutputT>,Offset,BatchLogObserver.OnNextContext,OutputT> implements Serializable
-
Class cz.o2.proxima.flink.core.CommitLogSourceFunction extends cz.o2.proxima.flink.core.AbstractLogSourceFunction<CommitLogReader,cz.o2.proxima.flink.core.CommitLogSourceFunction.LogObserver<OutputT>,Offset,CommitLogObserver.OnNextContext,OutputT> implements Serializable
-
-
Package cz.o2.proxima.flink.utils
-
Class cz.o2.proxima.flink.utils.FlinkGlobalWatermarkTracker extends java.lang.Object implements Serializable
-
Serialized Fields
-
flinkMasterRest
java.net.URL flinkMasterRest
-
globalWatermark
long globalWatermark
-
jobId
java.lang.String jobId
-
jobName
java.lang.String jobName
-
lastUpdate
long lastUpdate
-
name
java.lang.String name
-
updateInterval
long updateInterval
-
vertexNames
java.util.List<java.lang.String> vertexNames
-
vertices
java.util.List<java.lang.String> vertices
-
-
-
-
Package cz.o2.proxima.scheme.avro
-
Class cz.o2.proxima.scheme.avro.AvroSerializerFactory extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
serializersCache
java.util.Map<java.net.URI,ValueSerializer<?>> serializersCache
-
-
-
Package cz.o2.proxima.scheme.confluent
-
Class cz.o2.proxima.scheme.confluent.SchemaRegistrySerializerFactory extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
cache
java.util.Map<java.net.URI,ValueSerializer<?>> cache
-
-
-
Package cz.o2.proxima.scheme.proto
-
Class cz.o2.proxima.scheme.proto.JsonProtoSerializerFactory extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
serializers
java.util.Map<java.net.URI,ValueSerializer<?>> serializers
-
-
Class cz.o2.proxima.scheme.proto.ProtoMessageValueAccessor extends java.lang.Object implements Serializable
-
Serialized Fields
-
defaultValueFactory
Factory<T extends com.google.protobuf.Message> defaultValueFactory
-
fieldAccessors
java.util.Map<java.lang.String,AttributeValueAccessor<?,?>> fieldAccessors
-
-
-
Class cz.o2.proxima.scheme.proto.ProtoSerializerFactory extends java.lang.Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
parsers
java.util.Map<java.net.URI,ValueSerializer<?>> parsers
-
-
-
Package cz.o2.proxima.tools.groovy
-
Class cz.o2.proxima.tools.groovy.AbstractWindowedStreamTest extends cz.o2.proxima.tools.groovy.StreamTest implements Serializable
- serialVersionUID:
- 1L
-
Class cz.o2.proxima.tools.groovy.JavaTypedClosure extends groovy.lang.Closure<T extends java.lang.Object> implements Serializable
-
Serialized Fields
-
delegate
groovy.lang.Closure<T extends java.lang.Object> delegate
-
type
java.lang.Class<? extends T extends java.lang.Object> type
-
-
-
Class cz.o2.proxima.tools.groovy.StreamTest extends cz.o2.proxima.tools.groovy.AbstractStreamTest implements Serializable
-
Class cz.o2.proxima.tools.groovy.TimeWindowedStreamTest extends cz.o2.proxima.tools.groovy.AbstractWindowedStreamTest implements Serializable
-
Class cz.o2.proxima.tools.groovy.WindowedStreamTest extends cz.o2.proxima.tools.groovy.AbstractWindowedStreamTest implements Serializable
-