Uses of Interface
org.nuxeo.lib.stream.codec.Codec
-
Packages that use Codec Package Description org.nuxeo.ecm.core.blob.stream org.nuxeo.ecm.core.bulk org.nuxeo.ecm.core.model.stream org.nuxeo.ecm.core.work org.nuxeo.ecm.platform.audit.stream org.nuxeo.elasticsearch.bulk org.nuxeo.importer.stream org.nuxeo.importer.stream.consumer org.nuxeo.lib.stream.codec org.nuxeo.lib.stream.computation The Computation pattern with a Log implementation.org.nuxeo.lib.stream.computation.log Computation pattern implemented with Logorg.nuxeo.lib.stream.log The Log interface with Chronicle and Kafka implementation.org.nuxeo.lib.stream.log.chronicle org.nuxeo.lib.stream.log.internals org.nuxeo.lib.stream.log.kafka org.nuxeo.lib.stream.pattern.consumer org.nuxeo.lib.stream.pattern.consumer.internals org.nuxeo.lib.stream.pattern.producer org.nuxeo.lib.stream.tools.command org.nuxeo.runtime.codec org.nuxeo.runtime.pubsub org.nuxeo.runtime.stream -
-
Uses of Codec in org.nuxeo.ecm.core.blob.stream
Fields in org.nuxeo.ecm.core.blob.stream declared as Codec Modifier and Type Field Description protected Codec<BlobDomainEvent>
BlobDomainEventProducer. codec
protected Codec<BlobDomainEvent>
StreamOrphanBlobGC.BlobGCComputation. codec
-
Uses of Codec in org.nuxeo.ecm.core.bulk
Methods in org.nuxeo.ecm.core.bulk that return Codec Modifier and Type Method Description static Codec<BulkBucket>
BulkCodecs. getBucketCodec()
static Codec<BulkCommand>
BulkCodecs. getCommandCodec()
static Codec<DataBucket>
BulkCodecs. getDataBucketCodec()
static Codec<BulkStatus>
BulkCodecs. getStatusCodec()
-
Uses of Codec in org.nuxeo.ecm.core.model.stream
Fields in org.nuxeo.ecm.core.model.stream declared as Codec Modifier and Type Field Description protected Codec<DocumentDomainEvent>
DocumentDomainEventProducer. codec
protected Codec<DocumentDomainEvent>
StreamDocumentGC.DocumentGCComputation. codec
-
Uses of Codec in org.nuxeo.ecm.core.work
Fields in org.nuxeo.ecm.core.work declared as Codec Modifier and Type Field Description static Codec<Record>
WorkManagerImpl. DEAD_LETTER_QUEUE_CODEC
Methods in org.nuxeo.ecm.core.work that return Codec Modifier and Type Method Description protected Codec<Record>
StreamWorkManager. getCodec()
-
Uses of Codec in org.nuxeo.ecm.platform.audit.stream
Fields in org.nuxeo.ecm.platform.audit.stream declared as Codec Modifier and Type Field Description protected Codec<AuditDomainEvent>
AuditDomainEventProducer. codec
-
Uses of Codec in org.nuxeo.elasticsearch.bulk
Fields in org.nuxeo.elasticsearch.bulk declared as Codec Modifier and Type Field Description protected Codec<DataBucket>
BulkIndexComputation. codec
protected Codec<BulkStatus>
IndexCompletionComputation. codec
-
Uses of Codec in org.nuxeo.importer.stream
Methods in org.nuxeo.importer.stream that return Codec Modifier and Type Method Description static Codec<BlobMessage>
StreamImporters. getBlobCodec()
static Codec<BlobInfoMessage>
StreamImporters. getBlobInfoCodec()
static Codec<DocumentMessage>
StreamImporters. getDocCodec()
-
Uses of Codec in org.nuxeo.importer.stream.consumer
Constructors in org.nuxeo.importer.stream.consumer with parameters of type Codec Constructor Description DocumentConsumerPool(String logName, LogManager manager, Codec<M> codec, ConsumerFactory<M> factory, ConsumerPolicy consumerPolicy)
-
Uses of Codec in org.nuxeo.lib.stream.codec
Classes in org.nuxeo.lib.stream.codec that implement Codec Modifier and Type Class Description class
AvroBinaryCodec<T>
Avro Binary format, there is no header, the schema must be the same for encoder and decoder.class
AvroConfluentCodec<T>
Use the Confluent Avro encoding which differs from Avro message, the schema store is a REST Confluent Schema Registry.class
AvroJsonCodec<T>
JSON Avro format for debugging purpose.class
AvroMessageCodec<T>
Avro Single object encoding: magic 2 bytes + schema fingerprint 8 bytes + avro binary.class
NoCodec
Special no operation codec, can be used as marker.class
SerializableCodec<T extends Serializable>
JavaSerializable
encoding. -
Uses of Codec in org.nuxeo.lib.stream.computation
Fields in org.nuxeo.lib.stream.computation declared as Codec Modifier and Type Field Description protected Codec<Record>
Settings. defaultCodec
Fields in org.nuxeo.lib.stream.computation with type parameters of type Codec Modifier and Type Field Description protected Map<Name,Codec<Record>>
Settings. codecs
Methods in org.nuxeo.lib.stream.computation that return Codec Modifier and Type Method Description Codec<Record>
Settings. getCodec(String streamName)
Gets the codec for a stream.Codec<Record>
Settings. getCodec(Name streamName)
Gets the codec for a stream.Methods in org.nuxeo.lib.stream.computation with parameters of type Codec Modifier and Type Method Description Settings
Settings. setCodec(String streamName, Codec<Record> codec)
Sets the codec for a stream.Settings
Settings. setCodec(Name streamName, Codec<Record> codec)
Sets the codec for a stream.Constructors in org.nuxeo.lib.stream.computation with parameters of type Codec Constructor Description Settings(int defaultConcurrency, int defaultPartitions, Codec<Record> defaultCodec)
Default concurrency and partition to use if not specified explicitly.Settings(int defaultConcurrency, int defaultPartitions, Codec<Record> defaultCodec, ComputationPolicy defaultPolicy)
Settings(int defaultConcurrency, int defaultPartitions, Codec<Record> defaultCodec, ComputationPolicy defaultPolicy, RecordFilterChain defaultFilter)
Settings(int defaultConcurrency, int defaultPartitions, Codec<Record> defaultCodec, ComputationPolicy defaultPolicy, RecordFilterChain defaultFilter, boolean defaultExternal)
-
Uses of Codec in org.nuxeo.lib.stream.computation.log
Fields in org.nuxeo.lib.stream.computation.log declared as Codec Modifier and Type Field Description static Codec<Record>
LogStreamManager. INTERNAL_CODEC
Methods in org.nuxeo.lib.stream.computation.log that return Codec Modifier and Type Method Description protected Codec<Record>
LogStreamManager. getCodec(Collection<Name> streams)
protected Codec<Record>
LogStreamProcessor. getCodecForStreams(String name, Set<String> streams)
-
Uses of Codec in org.nuxeo.lib.stream.log
Methods in org.nuxeo.lib.stream.log that return Codec Modifier and Type Method Description Codec<M>
LogAppender. getCodec()
Returns the codec used to write record.Codec<M>
LogTailer. getCodec()
Returns the codec used to read the records.Methods in org.nuxeo.lib.stream.log with parameters of type Codec Modifier and Type Method Description default <M extends Externalizable>
LogTailer<M>LogManager. createTailer(String group, String name, Codec<M> codec)
Deprecated.since 11.1 useLogManager.createTailer(Name, Name, Codec)
insteaddefault <M extends Externalizable>
LogTailer<M>LogManager. createTailer(String group, Collection<LogPartition> partitions, Codec<M> codec)
Deprecated.since 11.1 useLogManager.createTailer(Name, Name, Codec)
(Name)} insteaddefault <M extends Externalizable>
LogTailer<M>LogManager. createTailer(String group, LogPartition partition, Codec<M> codec)
Deprecated.since 11.1 useLogManager.createTailer(Name, LogPartition, Codec)
instead<M extends Externalizable>
LogTailer<M>LogManager. createTailer(Name group, Collection<LogPartition> partitions, Codec<M> codec)
Creates a tailer for a consumergroup
and assign multiplepartitions
.default <M extends Externalizable>
LogTailer<M>LogManager. createTailer(Name group, LogPartition partition, Codec<M> codec)
Creates a tailer for a consumergroup
and assign a singlepartition
.default <M extends Externalizable>
LogTailer<M>LogManager. createTailer(Name group, Name name, Codec<M> codec)
Creates a tailer for a consumergroup
and assigns allpartitions
of the Log.<M extends Externalizable>
LogTailer<M>UnifiedLogManager. createTailer(Name group, Collection<LogPartition> partitions, Codec<M> codec)
default <M extends Externalizable>
LogAppender<M>LogManager. getAppender(String name, Codec<M> codec)
Deprecated.since 11.1 useLogManager.getAppender(Name, Codec)
instead<M extends Externalizable>
LogAppender<M>LogManager. getAppender(Name name, Codec<M> codec)
Gets an appender for the Log namedname
, usescodec
to encode records.<M extends Externalizable>
LogAppender<M>UnifiedLogManager. getAppender(Name name, Codec<M> codec)
default <M extends Externalizable>
LatencyLogManager. getLatency(String name, String group, Codec<M> codec, Function<M,Long> timestampExtractor, Function<M,String> keyExtractor)
Deprecated.since 11.1 useLogManager.getLatencyPerPartition(Name, Name, Codec, Function, Function)
insteaddefault <M extends Externalizable>
LatencyLogManager. getLatency(Name name, Name group, Codec<M> codec, Function<M,Long> timestampExtractor, Function<M,String> keyExtractor)
Returns the latency between consumergroup
and producers for a Log.default <M extends Externalizable>
List<Latency>LogManager. getLatencyPerPartition(String name, String group, Codec<M> codec, Function<M,Long> timestampExtractor, Function<M,String> keyExtractor)
Deprecated.since 11.1 useLogManager.getLatencyPerPartition(Name, Name, Codec, Function, Function)
instead<M extends Externalizable>
List<Latency>LogManager. getLatencyPerPartition(Name name, Name group, Codec<M> codec, Function<M,Long> timestampExtractor, Function<M,String> keyExtractor)
Returns the lag with latency.<M extends Externalizable>
List<Latency>UnifiedLogManager. getLatencyPerPartition(Name name, Name group, Codec<M> codec, Function<M,Long> timestampExtractor, Function<M,String> keyExtractor)
default <M extends Externalizable>
LogTailer<M>LogManager. subscribe(String group, Collection<String> names, RebalanceListener listener, Codec<M> codec)
Deprecated.since 11.1 useLogManager.subscribe(Name, Collection, RebalanceListener, Codec)
instead<M extends Externalizable>
LogTailer<M>LogManager. subscribe(Name group, Collection<Name> names, RebalanceListener listener, Codec<M> codec)
Creates a tailer for a consumerÂgroup
and subscribe to multiple Logs.<M extends Externalizable>
LogTailer<M>UnifiedLogManager. subscribe(Name group, Collection<Name> names, RebalanceListener listener, Codec<M> codec)
-
Uses of Codec in org.nuxeo.lib.stream.log.chronicle
Fields in org.nuxeo.lib.stream.log.chronicle declared as Codec Modifier and Type Field Description protected Codec<M>
ChronicleCompoundLogTailer. codec
protected Codec<M>
ChronicleLogAppender. codec
protected Codec<M>
ChronicleLogTailer. codec
Methods in org.nuxeo.lib.stream.log.chronicle that return Codec Modifier and Type Method Description Codec<M>
ChronicleCompoundLogTailer. getCodec()
Codec<M>
ChronicleLogAppender. getCodec()
Codec<M>
ChronicleLogTailer. getCodec()
Methods in org.nuxeo.lib.stream.log.chronicle with parameters of type Codec Modifier and Type Method Description static <M extends Externalizable>
ChronicleLogAppender<M>ChronicleLogAppender. create(ChronicleLogConfig config, Name name, int size, Codec<M> codec)
Create a new log<M extends Externalizable>
CloseableLogAppender<M>ChronicleLogManager. createAppender(Name name, Codec<M> codec)
LogTailer<M>
ChronicleLogAppender. createTailer(LogPartition partition, Name group, Codec<M> codec)
protected <M extends Externalizable>
LogTailer<M>ChronicleLogManager. doCreateTailer(Collection<LogPartition> partitions, Name group, Codec<M> codec)
protected <M extends Externalizable>
LogTailer<M>ChronicleLogManager. doSubscribe(Name group, Collection<Name> names, RebalanceListener listener, Codec<M> codec)
static <M extends Externalizable>
ChronicleLogAppender<M>ChronicleLogAppender. open(ChronicleLogConfig config, Name name, Codec<M> codec)
Open an existing log.static <M extends Externalizable>
ChronicleLogAppender<M>ChronicleLogAppender. openWithoutRetention(ChronicleLogConfig config, Name name, Codec<M> codec)
Constructors in org.nuxeo.lib.stream.log.chronicle with parameters of type Codec Constructor Description ChronicleLogAppender(ChronicleLogConfig config, Name name, int size, Codec<M> codec)
Create a new LogChronicleLogAppender(ChronicleLogConfig config, Name name, Codec<M> codec, boolean withRetention)
Open an existing LogChronicleLogTailer(Codec<M> codec, String basePath, net.openhft.chronicle.queue.ExcerptTailer cqTailer, LogPartition partition, Name group, ChronicleRetentionDuration retention)
-
Uses of Codec in org.nuxeo.lib.stream.log.internals
Methods in org.nuxeo.lib.stream.log.internals that return Codec Modifier and Type Method Description protected <M extends Externalizable>
Codec<M>AbstractLogManager. guessCodec(Collection<LogPartition> partitions)
Methods in org.nuxeo.lib.stream.log.internals with parameters of type Codec Modifier and Type Method Description protected <M extends Externalizable>
voidAbstractLogManager. checkInvalidCodec(LogPartition partition, Codec<M> codec)
protected abstract <M extends Externalizable>
CloseableLogAppender<M>AbstractLogManager. createAppender(Name name, Codec<M> codec)
<M extends Externalizable>
LogTailer<M>AbstractLogManager. createTailer(Name group, Collection<LogPartition> partitions, Codec<M> codec)
protected abstract <M extends Externalizable>
LogTailer<M>AbstractLogManager. doCreateTailer(Collection<LogPartition> partitions, Name group, Codec<M> codec)
protected abstract <M extends Externalizable>
LogTailer<M>AbstractLogManager. doSubscribe(Name group, Collection<Name> names, RebalanceListener listener, Codec<M> codec)
<M extends Externalizable>
LogAppender<M>AbstractLogManager. getAppender(Name name, Codec<M> codec)
<M extends Externalizable>
List<Latency>AbstractLogManager. getLatencyPerPartition(Name name, Name group, Codec<M> codec, Function<M,Long> timestampExtractor, Function<M,String> keyExtractor)
protected <M extends Externalizable>
booleanAbstractLogManager. sameCodec(Codec<M> codec1, Codec<M> codec2)
<M extends Externalizable>
LogTailer<M>AbstractLogManager. subscribe(Name group, Collection<Name> names, RebalanceListener listener, Codec<M> codec)
-
Uses of Codec in org.nuxeo.lib.stream.log.kafka
Fields in org.nuxeo.lib.stream.log.kafka declared as Codec Modifier and Type Field Description protected Codec<M>
KafkaLogAppender. codec
protected Codec<M>
KafkaLogTailer. codec
protected Codec<M>
KafkaLogTailer. decodeCodec
protected Codec<M>
KafkaLogAppender. encodingCodec
Methods in org.nuxeo.lib.stream.log.kafka that return Codec Modifier and Type Method Description Codec<M>
KafkaLogAppender. getCodec()
Codec<M>
KafkaLogTailer. getCodec()
Methods in org.nuxeo.lib.stream.log.kafka with parameters of type Codec Modifier and Type Method Description static <M extends Externalizable>
KafkaLogTailer<M>KafkaLogTailer. createAndAssign(Codec<M> codec, NameResolver resolver, Collection<LogPartition> partitions, Name group, Properties consumerProps)
static <M extends Externalizable>
KafkaLogTailer<M>KafkaLogTailer. createAndSubscribe(Codec<M> codec, NameResolver resolver, Collection<Name> names, Name group, Properties consumerProps, RebalanceListener listener)
<M extends Externalizable>
CloseableLogAppender<M>KafkaLogManager. createAppender(Name name, Codec<M> codec)
protected <M extends Externalizable>
LogTailer<M>KafkaLogManager. doCreateTailer(Collection<LogPartition> partitions, Name group, Codec<M> codec)
protected <M extends Externalizable>
LogTailer<M>KafkaLogManager. doSubscribe(Name group, Collection<Name> names, RebalanceListener listener, Codec<M> codec)
static <M extends Externalizable>
KafkaLogAppender<M>KafkaLogAppender. open(Codec<M> codec, NameResolver resolver, Name name, Properties producerProperties, Properties consumerProperties)
Constructors in org.nuxeo.lib.stream.log.kafka with parameters of type Codec Constructor Description KafkaLogTailer(Codec<M> codec, NameResolver resolver, Name group, Properties consumerProps)
-
Uses of Codec in org.nuxeo.lib.stream.pattern.consumer
Fields in org.nuxeo.lib.stream.pattern.consumer declared as Codec Modifier and Type Field Description protected Codec<M>
ConsumerPool. codec
Constructors in org.nuxeo.lib.stream.pattern.consumer with parameters of type Codec Constructor Description ConsumerPool(String logName, LogManager manager, Codec<M> codec, ConsumerFactory<M> factory, ConsumerPolicy policy)
-
Uses of Codec in org.nuxeo.lib.stream.pattern.consumer.internals
Methods in org.nuxeo.lib.stream.pattern.consumer.internals with parameters of type Codec Modifier and Type Method Description protected LogTailer<M>
ConsumerRunner. createTailer(LogManager manager, Codec<M> codec, List<LogPartition> defaultAssignments)
Constructors in org.nuxeo.lib.stream.pattern.consumer.internals with parameters of type Codec Constructor Description ConsumerRunner(ConsumerFactory<M> factory, ConsumerPolicy policy, LogManager manager, Codec<M> codec, List<LogPartition> defaultAssignments)
-
Uses of Codec in org.nuxeo.lib.stream.pattern.producer
Fields in org.nuxeo.lib.stream.pattern.producer declared as Codec Modifier and Type Field Description protected Codec<M>
ProducerPool. codec
Constructors in org.nuxeo.lib.stream.pattern.producer with parameters of type Codec Constructor Description ProducerPool(String logName, LogManager manager, Codec<M> codec, ProducerFactory<M> factory, short nbThreads)
-
Uses of Codec in org.nuxeo.lib.stream.tools.command
Fields in org.nuxeo.lib.stream.tools.command declared as Codec Modifier and Type Field Description protected Codec<Record>
LatencyTrackerComputation. codec
Methods in org.nuxeo.lib.stream.tools.command that return Codec Modifier and Type Method Description protected Codec<Record>
Command. getRecordCodec(String codec)
Methods in org.nuxeo.lib.stream.tools.command with parameters of type Codec Modifier and Type Method Description protected void
LatencyCommand. latency(LogManager manager, Codec<Record> codec)
protected void
LatencyCommand. latency(LogManager manager, Name name, Codec<Record> codec)
Constructors in org.nuxeo.lib.stream.tools.command with parameters of type Codec Constructor Description LatencyDatadogComputation(LogManager manager, List<Name> logNames, String apiKey, List<String> tags, String basePrefix, String computationName, int intervalSecond, int count, boolean partition, boolean verbose, Codec<Record> codec)
LatencyMonitorComputation(LogManager manager, List<Name> logNames, String host, int port, boolean udp, String basePrefix, String computationName, int intervalSecond, int count, boolean partition, boolean verbose, Codec<Record> codec)
LatencyMonitorComputation(LogManager manager, List<Name> logNames, String host, int port, boolean udp, String basePrefix, String computationName, int intervalSecond, int count, boolean verbose, Codec<Record> codec)
Deprecated.LatencyTrackerComputation(LogManager manager, List<Name> logNames, String computationName, int intervalSecond, int count, boolean verbose, Codec<Record> codec, int outputStream)
-
Uses of Codec in org.nuxeo.runtime.codec
Classes in org.nuxeo.runtime.codec that implement Codec Modifier and Type Class Description class
AvroRecordCodec<T extends Record>
Instead of having an Avro Record envelop that contains a data encoded in Avro, this structure is a flat Avro message joining schemas of the Record and data.Methods in org.nuxeo.runtime.codec that return Codec Modifier and Type Method Description <T> Codec<T>
CodecService. getCodec(String codecName, Class<T> objectClass)
Returns a codec able to code and decode object of type T<T> Codec<T>
CodecServiceImpl. getCodec(String codecName, Class<T> objectClass)
<T> Codec<T>
AvroCodecFactory. newCodec(Class<T> objectClass)
<T> Codec<T>
AvroRecordCodecFactory. newCodec(Class<T> objectClass)
<T> Codec<T>
CodecFactory. newCodec(Class<T> objectClass)
Returns a codec object enables to encode/decode object ot class T.<T> Codec<T>
NoCodecFactory. newCodec(Class<T> objectClass)
<T> Codec<T>
SerializableCodecFactory. newCodec(Class<T> objectClass)
-
Uses of Codec in org.nuxeo.runtime.pubsub
Fields in org.nuxeo.runtime.pubsub declared as Codec Modifier and Type Field Description protected Codec<Record>
StreamPubSubProvider. codec
-
Uses of Codec in org.nuxeo.runtime.stream
Fields in org.nuxeo.runtime.stream declared as Codec Modifier and Type Field Description protected Codec<Record>
StreamMetricsComputation. codec
Methods in org.nuxeo.runtime.stream with parameters of type Codec Modifier and Type Method Description boolean
StreamMetricsComputation.LatencyMetric. update(LogManager manager, Codec<Record> codec)
-