Uses of Class
org.nuxeo.lib.stream.log.Name
Packages that use Name
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 Name in org.nuxeo.ecm.core.bulk
Fields in org.nuxeo.ecm.core.bulk declared as NameModifier and TypeFieldDescriptionstatic final Name
BulkServiceImpl.COMMAND_STREAM_NAME
static final Name
BulkServiceImpl.DONE_STREAM_NAME
static final Name
BulkServiceImpl.STATUS_STREAM_NAME
-
Uses of Name in org.nuxeo.ecm.core.work
Fields in org.nuxeo.ecm.core.work declared as NameModifier and TypeFieldDescriptionstatic final Name
WorkManagerImpl.DEAD_LETTER_QUEUE
The dead letter queue stream name. -
Uses of Name in org.nuxeo.ecm.restapi.server.jaxrs.management
Fields in org.nuxeo.ecm.restapi.server.jaxrs.management declared as Name -
Uses of Name in org.nuxeo.importer.stream.producer
Methods in org.nuxeo.importer.stream.producer that return NameModifier and TypeMethodDescriptionprotected Name
RandomDocumentMessageProducerFactory.getGroupName
(int producerId) -
Uses of Name in org.nuxeo.lib.stream.computation
Fields in org.nuxeo.lib.stream.computation with type parameters of type NameModifier and TypeFieldDescriptionSettings.codecs
Settings.concurrencies
Settings.externals
protected final Map<Name,
RecordFilterChain> Settings.filters
Settings.partitions
protected final Map<Name,
ComputationPolicy> Settings.policies
Methods in org.nuxeo.lib.stream.computation with parameters of type NameModifier and TypeMethodDescriptionSettings.addFilter
(Name streamName, RecordFilter filter) Add a filterGets the codec for a stream.int
Settings.getConcurrency
(Name computationName) Settings.getFilterChain
(Name streamName) Gets the filter chain for a stream.int
Settings.getPartitions
(Name streamName) Gets the policy for a computation.boolean
Settings.isExternal
(Name streamName) Sets the codec for a stream.Settings.setConcurrency
(Name computationName, int concurrency) Settings.setExternal
(Name streamName, boolean external) Settings.setPartitions
(Name streamName, int partitions) Sets the number of partitions for a stream.Settings.setPolicy
(Name computationName, ComputationPolicy policy) Sets the policy for a computation, when using default as computationName this sets the default policy for all computations in the processor.boolean
StreamProcessor.startComputation
(Name computation) Start a computation thread pool that has been stopped usingStreamProcessor.stopComputation(Name)
boolean
StreamProcessor.stopComputation
(Name computation) Stop a computation thread pool. -
Uses of Name in org.nuxeo.lib.stream.computation.log
Fields in org.nuxeo.lib.stream.computation.log with type parameters of type NameModifier and TypeFieldDescriptionprotected final Map<Name,
RecordFilterChain> LogStreamManager.filters
LogStreamManager.streams
Methods in org.nuxeo.lib.stream.computation.log with parameters of type NameModifier and TypeMethodDescriptionLogStreamManager.createTailer
(Name computationName, Collection<LogPartition> streamPartitions) protected void
LogStreamManager.initInternalStream
(Name stream) boolean
LogStreamProcessor.startComputation
(Name computation) boolean
LogStreamProcessor.stopComputation
(Name computation) LogStreamManager.subscribe
(Name computationName, Collection<Name> streams, RebalanceListener listener) boolean
LogStreamManager.supportSubscribe
(Name stream) Returnstrue
if theLogStreamManager.subscribe(org.nuxeo.lib.stream.log.Name, java.util.Collection<org.nuxeo.lib.stream.log.Name>, org.nuxeo.lib.stream.log.RebalanceListener)
method is supported for the specific stream.Method parameters in org.nuxeo.lib.stream.computation.log with type arguments of type NameModifier and TypeMethodDescriptionLogStreamManager.getCodec
(Collection<Name> streams) LogStreamManager.subscribe
(Name computationName, Collection<Name> streams, RebalanceListener listener) -
Uses of Name in org.nuxeo.lib.stream.log
Fields in org.nuxeo.lib.stream.log declared as NameMethods in org.nuxeo.lib.stream.log that return NameModifier and TypeMethodDescriptionLogTailer.group()
Returns the consumer group.LogAppender.name()
Returns the Log's name.LogPartition.name()
Returns the Log's namestatic Name
static Name
static Name
Methods in org.nuxeo.lib.stream.log that return types with arguments of type NameModifier and TypeMethodDescriptionLogManager.listAllNames()
Returns all the Log names.UnifiedLogManager.listAllNames()
LogManager.listConsumerGroups
(Name name) List the consumer groups for a Log.UnifiedLogManager.listConsumerGroups
(Name name) Methods in org.nuxeo.lib.stream.log with parameters of type NameModifier and TypeMethodDescriptionboolean
LogManager.createIfNotExists
(Name name, int size) Creates a new Log withsize
partitions if the Log does not exists.boolean
UnifiedLogManager.createIfNotExists
(Name name, int size) default <M extends Externalizable>
LogTailer<M>LogManager.createTailer
(Name group, Collection<LogPartition> partitions) Creates a tailer for a consumergroup
and assign multiplepartitions
.<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) Creates a tailer for a consumergroup
and assign a singlepartition
.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) Creates a tailer for a consumergroup
and assign allpartitions
of the Log.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) boolean
Tries to delete a Log.boolean
default void
LogManager.deleteRecords
(Name name) Delete all records of a stream by moving the first offsets to end of each partition.void
UnifiedLogManager.deleteRecords
(Name name) boolean
Returnstrue
if a Log with thisname
exists.boolean
default <M extends Externalizable>
LogAppender<M>LogManager.getAppender
(Name name) Gets an appender for the Log namedname
, uses an already defined codec or the legacy encoding to encode records.<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 LogLag
Returns the lag between consumergroup
and producers for a Log.LogManager.getLagPerPartition
(Name name, Name group) Returns the lag between consumergroup
and the producers for each partition.UnifiedLogManager.getLagPerPartition
(Name name, Name group) default <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.<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) protected LogManager
UnifiedLogManager.getManager
(Name name) protected LogManager
UnifiedLogManager.getManager
(Name name, Name group) LogManager.listConsumerGroups
(Name name) List the consumer groups for a Log.UnifiedLogManager.listConsumerGroups
(Name name) boolean
boolean
boolean
boolean
static LogPartition
int
Returns the number of partition of a Log.int
default <M extends Externalizable>
LogTailer<M>LogManager.subscribe
(Name group, Collection<Name> names, RebalanceListener listener) <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) boolean
LogManager.supportSubscribe
(Name stream) Returnstrue
if theLogManager.subscribe(org.nuxeo.lib.stream.log.Name, java.util.Collection<org.nuxeo.lib.stream.log.Name>, org.nuxeo.lib.stream.log.RebalanceListener, org.nuxeo.lib.stream.codec.Codec<M>)
method is supported for the specific Log.boolean
UnifiedLogManager.supportSubscribe
(Name stream) boolean
Wait for consumer to process a message up to the offset.Method parameters in org.nuxeo.lib.stream.log with type arguments of type NameModifier and TypeMethodDescriptiondefault <M extends Externalizable>
LogTailer<M>LogManager.subscribe
(Name group, Collection<Name> names, RebalanceListener listener) <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) Constructors in org.nuxeo.lib.stream.log with parameters of type Name -
Uses of Name in org.nuxeo.lib.stream.log.internals
Fields in org.nuxeo.lib.stream.log.internals declared as NameModifier and TypeFieldDescriptionprotected static final Name
AbstractLogManager.ADMIN_GROUP
final Name
LogPartitionGroup.group
final Name
LogPartitionGroup.name
Fields in org.nuxeo.lib.stream.log.internals with type parameters of type NameModifier and TypeFieldDescriptionprotected final Map<Name,
CloseableLogAppender> AbstractLogManager.appenders
Methods in org.nuxeo.lib.stream.log.internals with parameters of type NameModifier and TypeMethodDescriptionprotected void
AbstractLogManager.checkInvalidAssignment
(Name group, LogPartition partition) protected abstract void
protected abstract <M extends Externalizable>
CloseableLogAppender<M>AbstractLogManager.createAppender
(Name name, Codec<M> codec) boolean
AbstractLogManager.createIfNotExists
(Name name, int size) <M extends Externalizable>
LogTailer<M>AbstractLogManager.createTailer
(Name group, Collection<LogPartition> partitions, Codec<M> codec) boolean
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) AbstractLogManager.getLagPerPartition
(Name name, Name group) <M extends Externalizable>
List<Latency>AbstractLogManager.getLatencyPerPartition
(Name name, Name group, Codec<M> codec, Function<M, Long> timestampExtractor, Function<M, String> keyExtractor) protected abstract int
int
<M extends Externalizable>
LogTailer<M>AbstractLogManager.subscribe
(Name group, Collection<Name> names, RebalanceListener listener, Codec<M> codec) boolean
AbstractLogManager.supportSubscribe
(Name stream) Method parameters in org.nuxeo.lib.stream.log.internals with type arguments of type NameModifier and TypeMethodDescriptionprotected abstract <M extends Externalizable>
LogTailer<M>AbstractLogManager.doSubscribe
(Name group, Collection<Name> names, RebalanceListener listener, Codec<M> codec) <M extends Externalizable>
LogTailer<M>AbstractLogManager.subscribe
(Name group, Collection<Name> names, RebalanceListener listener, Codec<M> codec) Constructors in org.nuxeo.lib.stream.log.internals with parameters of type NameModifierConstructorDescriptionLogOffsetImpl
(Name name, int partition, long offset) LogPartitionGroup
(Name group, LogPartition mqp) LogPartitionGroup
(Name group, Name name, int partition) -
Uses of Name in org.nuxeo.lib.stream.log.kafka
Fields in org.nuxeo.lib.stream.log.kafka declared as NameModifier and TypeFieldDescriptionprotected final Name
KafkaLogTailer.group
protected final Name
KafkaLogAppender.name
Fields in org.nuxeo.lib.stream.log.kafka with type parameters of type NameMethods in org.nuxeo.lib.stream.log.kafka that return NameMethods in org.nuxeo.lib.stream.log.kafka that return types with arguments of type NameModifier and TypeMethodDescriptionKafkaLogManager.listAllNames()
KafkaLogManager.listConsumerGroups
(Name name) Methods in org.nuxeo.lib.stream.log.kafka with parameters of type NameModifier and TypeMethodDescriptionprotected static String
KafkaLogTailer.buildId
(Name group, Collection<LogPartition> partitions) protected static String
KafkaLogTailer.buildSubscribeId
(Name group, Collection<Name> names) void
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) boolean
void
KafkaLogManager.deleteRecords
(Name name) 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) boolean
protected KafkaLogConfig
protected KafkaLogConfig
KafkaLogManager.getLagPerPartition
(Name name, Name group) protected int
protected boolean
KafkaLogAppender.isProcessed
(Name group, org.apache.kafka.common.TopicPartition topicPartition, long offset) KafkaLogManager.listConsumerGroups
(Name name) static <M extends Externalizable>
KafkaLogAppender<M>KafkaLogAppender.open
(Codec<M> codec, NameResolver resolver, Name name, Properties producerProperties, Properties consumerProperties) boolean
KafkaLogManager.supportSubscribe
(Name stream) boolean
Method parameters in org.nuxeo.lib.stream.log.kafka with type arguments of type NameModifier and TypeMethodDescriptionprotected static String
KafkaLogTailer.buildSubscribeId
(Name group, Collection<Name> names) static <M extends Externalizable>
KafkaLogTailer<M>KafkaLogTailer.createAndSubscribe
(Codec<M> codec, NameResolver resolver, Collection<Name> names, Name group, Properties consumerProps, RebalanceListener listener) protected <M extends Externalizable>
LogTailer<M>KafkaLogManager.doSubscribe
(Name group, Collection<Name> names, RebalanceListener listener, Codec<M> codec) Constructors in org.nuxeo.lib.stream.log.kafka with parameters of type NameModifierConstructorDescriptionprotected
KafkaLogTailer
(Codec<M> codec, NameResolver resolver, Name group, Properties consumerProps) -
Uses of Name in org.nuxeo.lib.stream.log.mem
Methods in org.nuxeo.lib.stream.log.mem that return NameModifier and TypeMethodDescriptionMemCompoundLogTailer.group()
MemLogTailer.group()
MemLogAppender.name()
Methods in org.nuxeo.lib.stream.log.mem that return types with arguments of type NameModifier and TypeMethodDescriptionMemLog.getGroups()
MemLogPartition.getGroups()
MemLogManager.listAllNames()
MemLogs.listAllNames()
MemLogManager.listConsumerGroups
(Name name) Methods in org.nuxeo.lib.stream.log.mem with parameters of type NameModifier and TypeMethodDescriptionvoid
MemLogPartition.closeTailer
(Name group) long
void
<M extends Externalizable>
CloseableLogAppender<M>MemLogManager.createAppender
(Name name, Codec<M> codec) MemLogAppender.createTailer
(LogPartition partition, Name group, Codec<M> codec) MemLogPartition.createTailer
(Name group) boolean
boolean
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) boolean
boolean
MemLogPartition.getCommittedOffsetTracker
(Name group) MemLogManager.getLagPerPartition
(Name name, Name group) MemLogs.getLogOptional
(Name name) int
MemLogManager.listConsumerGroups
(Name name) boolean
Method parameters in org.nuxeo.lib.stream.log.mem with type arguments of type NameModifier and TypeMethodDescriptionprotected <M extends Externalizable>
LogTailer<M>MemLogManager.doSubscribe
(Name group, Collection<Name> names, RebalanceListener listener, Codec<M> codec) Constructors in org.nuxeo.lib.stream.log.mem with parameters of type NameModifierConstructorDescriptionMemCompoundLogTailer
(List<MemLogTailer<M>> tailers, Name group) MemLogAppender
(MemLogs memLogs, Name name, Codec<M> codec) MemLogTailer
(MemLog log, LogPartition partition, Name group, Codec<M> codec) MemPartitionTailer
(Name group, MemLogPartition.OffsetTracker offsetTracker) -
Uses of Name in org.nuxeo.lib.stream.pattern.consumer
Methods in org.nuxeo.lib.stream.pattern.consumer that return Name -
Uses of Name in org.nuxeo.lib.stream.tools.command
Fields in org.nuxeo.lib.stream.tools.command declared as NameModifier and TypeFieldDescriptionprotected static final Name
RestoreCommand.GROUP
protected Name
RestoreCommand.input
Fields in org.nuxeo.lib.stream.tools.command with type parameters of type NameModifier and TypeFieldDescriptionLatencyTrackerComputation.logNames
MonitorCommand.logNames
RestoreCommand.logNames
TrackerCommand.logNames
Methods in org.nuxeo.lib.stream.tools.command that return types with arguments of type NameModifier and TypeMethodDescriptionMonitorCommand.getLogNames
(LogManager manager, String names) RestoreCommand.getLogNames
(LogManager manager, String names) TrackerCommand.getLogNames
(LogManager manager, String names) Methods in org.nuxeo.lib.stream.tools.command with parameters of type NameModifier and TypeMethodDescriptionprotected void
AppendCommand.append
(LogManager manager, Name name, int partition, String codec, Path input) protected void
protected boolean
CopyCommand.copy
(LogManager manager, Name src, String srcCodec, Name dest, String destCodec, Name group) protected <T extends Externalizable>
LogTailer<T>PositionCommand.createTailer
(LogManager manager, Name name, int partition, Name group) protected void
DumpCommand.dump
(LogManager manager, Name name, int partition, Name group, int limit, String codec, Path output) protected void
TailCommand.follow
(LogManager manager, Name name, Name group, Renderer render, int timeout, String codec) protected LogLag
PositionCommand.getLag
(LogManager manager, Name group, Name name, int partition) DumpCommand.getTailer
(LogManager manager, Name name, int partition, Name group, String codec) protected String
protected void
LagCommand.lag
(LogManager manager, Name name) protected void
LatencyCommand.latency
(LogManager manager, Name name, Codec<Record> codec) protected boolean
PositionCommand.positionAfterDate
(LogManager manager, Name group, Name name, int partition, long timestamp) protected boolean
PositionCommand.positionToOffset
(LogManager manager, Name group, Name name, int partition, long offset) protected boolean
PositionCommand.positionToWatermark
(LogManager manager, Name group, Name name, int partition, long timestamp, String codec) protected void
LatencyDatadogComputation.publishMetrics
(Latency latency, String prefix, String partition, Name stream, Name group) protected void
protected void
LatencyCommand.renderLatency
(Name group, List<Latency> latencies) protected boolean
PositionCommand.reset
(LogManager manager, Name group, Name name, int partition) protected void
TailCommand.tail
(LogManager manager, Name name, Name group, int lines, Renderer render, String codec) protected boolean
PositionCommand.toEnd
(LogManager manager, Name group, Name name, int partition) protected void
WorkCatCommand.workStat
(LogManager manager, Name name, Name group, int limit, String codec) Constructor parameters in org.nuxeo.lib.stream.tools.command with type arguments of type NameModifierConstructorDescriptionLatencyDatadogComputation
(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 Name in org.nuxeo.runtime.pubsub
Fields in org.nuxeo.runtime.pubsub declared as Name -
Uses of Name in org.nuxeo.runtime.stream
Fields in org.nuxeo.runtime.stream with type parameters of type NameModifier and TypeFieldDescriptionStreamMetricsComputation.invalidStreams
StreamMetricsComputation.streams
Methods in org.nuxeo.runtime.stream that return NameMethods in org.nuxeo.runtime.stream that return types with arguments of type NameMethods in org.nuxeo.runtime.stream with parameters of type NameModifier and TypeMethodDescriptionboolean
StreamService.restartComputation
(Name computation) Restart the computation thread pool.boolean
StreamServiceImpl.restartComputation
(Name computation) boolean
StreamService.setComputationPositionAfterDate
(Name computation, Name stream, Instant dateTime) Moving computation position after a date.boolean
StreamServiceImpl.setComputationPositionAfterDate
(Name computation, Name stream, Instant after) boolean
StreamService.setComputationPositionToBeginning
(Name computation, Name stream) Moving computation position to the beginning of stream.boolean
StreamServiceImpl.setComputationPositionToBeginning
(Name computation, Name stream) boolean
StreamService.setComputationPositionToEnd
(Name computation, Name stream) Moving computation position to the end of stream.boolean
StreamServiceImpl.setComputationPositionToEnd
(Name computation, Name stream) boolean
StreamService.setComputationPositionToOffset
(Name computation, Name stream, int partition, long offset) Moving computation position to a specific offset for a partition.boolean
StreamServiceImpl.setComputationPositionToOffset
(Name computation, Name stream, int partition, long offset) boolean
StreamService.stopComputation
(Name computation) Stop computation thread pool immediately.boolean
StreamServiceImpl.stopComputation
(Name computation)