Uses of Interface
org.nuxeo.lib.stream.codec.Codec
Package
Description
The Computation pattern with a Log implementation.
Computation pattern implemented with Log
The Log interface with In-Memory and Kafka implementation.
-
Uses of Codec in org.nuxeo.ecm.core.blob.stream
Modifier and TypeFieldDescriptionprotected final Codec<BlobDomainEvent>
BlobDomainEventProducer.codec
protected final Codec<BlobDomainEvent>
StreamOrphanBlobGC.BlobGCComputation.codec
-
Uses of Codec in org.nuxeo.ecm.core.bulk
Modifier and TypeMethodDescriptionstatic 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
Modifier and TypeFieldDescriptionprotected final Codec<DocumentDomainEvent>
DocumentDomainEventProducer.codec
protected final Codec<DocumentDomainEvent>
StreamDocumentGC.DocumentGCComputation.codec
-
Uses of Codec in org.nuxeo.ecm.core.work
-
Uses of Codec in org.nuxeo.ecm.platform.audit.stream
Modifier and TypeFieldDescriptionprotected final Codec<AuditDomainEvent>
AuditDomainEventProducer.codec
-
Uses of Codec in org.nuxeo.elasticsearch.bulk
Modifier and TypeFieldDescriptionprotected Codec<DataBucket>
BulkIndexComputation.codec
protected Codec<BulkStatus>
IndexCompletionComputation.codec
-
Uses of Codec in org.nuxeo.importer.stream
Modifier and TypeMethodDescriptionstatic Codec<BlobMessage>
StreamImporters.getBlobCodec()
static Codec<BlobInfoMessage>
StreamImporters.getBlobInfoCodec()
static Codec<DocumentMessage>
StreamImporters.getDocCodec()
-
Uses of Codec in org.nuxeo.importer.stream.consumer
ModifierConstructorDescriptionDocumentConsumerPool
(String logName, LogManager manager, Codec<M> codec, ConsumerFactory<M> factory, ConsumerPolicy consumerPolicy) -
Uses of Codec in org.nuxeo.lib.stream.codec
Modifier and TypeClassDescriptionclass
Avro Binary format, there is no header, the schema must be the same for encoder and decoder.class
Use the Confluent Avro encoding which differs from Avro message, the schema store is a REST Confluent Schema Registry.class
JSON Avro format for debugging purpose.class
Avro Single object encoding: magic 2 bytes + schema fingerprint 8 bytes + avro binary.class
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
Modifier and TypeMethodDescriptionGets the codec for a stream.Gets the codec for a stream.Modifier and TypeMethodDescriptionSets the codec for a stream.Sets the codec for a stream.ModifierConstructorDescriptionDefault 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
-
Uses of Codec in org.nuxeo.lib.stream.log
Modifier and TypeMethodDescriptionLogAppender.getCodec()
Returns the codec used to write record.LogTailer.getCodec()
Returns the codec used to read the records.Modifier and TypeMethodDescriptiondefault <M extends Externalizable>
LogTailer<M>LogManager.createTailer
(String group, String name, Codec<M> codec) Deprecated.default <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.internals
Modifier and TypeMethodDescriptionprotected <M extends Externalizable>
Codec<M>AbstractLogManager.guessCodec
(Collection<LogPartition> partitions) Modifier and TypeMethodDescriptionprotected <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>
boolean<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
Modifier and TypeFieldDescriptionKafkaLogAppender.codec
KafkaLogTailer.codec
KafkaLogTailer.decodeCodec
KafkaLogAppender.encodingCodec
Modifier and TypeMethodDescriptionstatic <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) ModifierConstructorDescriptionprotected
KafkaLogTailer
(Codec<M> codec, NameResolver resolver, Name group, Properties consumerProps) -
Uses of Codec in org.nuxeo.lib.stream.log.mem
Modifier and TypeMethodDescriptionMemCompoundLogTailer.getCodec()
MemLogAppender.getCodec()
MemLogTailer.getCodec()
Modifier and TypeMethodDescription<M extends Externalizable>
CloseableLogAppender<M>MemLogManager.createAppender
(Name name, Codec<M> codec) MemLogAppender.createTailer
(LogPartition partition, Name group, Codec<M> codec) protected <M extends Externalizable>
LogTailer<M>MemLogManager.doCreateTailer
(Collection<LogPartition> partitions, Name group, Codec<M> codec) protected <M extends Externalizable>
LogTailer<M>MemLogManager.doSubscribe
(Name group, Collection<Name> names, RebalanceListener listener, Codec<M> codec) ModifierConstructorDescriptionMemLogAppender
(MemLogs memLogs, Name name, Codec<M> codec) MemLogTailer
(MemLog log, LogPartition partition, Name group, Codec<M> codec) -
Uses of Codec in org.nuxeo.lib.stream.pattern.consumer
ModifierConstructorDescriptionConsumerPool
(String logName, LogManager manager, Codec<M> codec, ConsumerFactory<M> factory, ConsumerPolicy policy) -
Uses of Codec in org.nuxeo.lib.stream.pattern.consumer.internals
Modifier and TypeMethodDescriptionConsumerRunner.createTailer
(LogManager manager, Codec<M> codec, List<LogPartition> defaultAssignments) ModifierConstructorDescriptionConsumerRunner
(ConsumerFactory<M> factory, ConsumerPolicy policy, LogManager manager, Codec<M> codec, List<LogPartition> defaultAssignments) -
Uses of Codec in org.nuxeo.lib.stream.pattern.producer
ModifierConstructorDescriptionProducerPool
(String logName, LogManager manager, Codec<M> codec, ProducerFactory<M> factory, short nbThreads) -
Uses of Codec in org.nuxeo.lib.stream.tools.command
Modifier and TypeMethodDescriptionprotected void
LatencyCommand.latency
(LogManager manager, Codec<Record> codec) protected void
LatencyCommand.latency
(LogManager manager, Name name, Codec<Record> codec) ModifierConstructorDescriptionLatencyDatadogComputation
(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.log4j
Modifier and TypeFieldDescriptionstatic final Codec<NuxeoLogEvent>
NuxeoStreamAppender.AVRO_CODEC
-
Uses of Codec in org.nuxeo.runtime.codec
Modifier and TypeClassDescriptionclass
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. -
Uses of Codec in org.nuxeo.runtime.pubsub
-
Uses of Codec in org.nuxeo.runtime.stream
Modifier and TypeMethodDescriptionboolean
StreamMetricsComputation.LatencyMetric.update
(LogManager manager, Codec<Record> codec)
LogManager.createTailer(Name, Name, Codec)
instead