Uses of Class
org.nuxeo.lib.stream.log.Name
-
Packages that use Name Package Description org.nuxeo.ecm.core.bulk org.nuxeo.ecm.core.work org.nuxeo.ecm.restapi.server.jaxrs.management org.nuxeo.importer.stream.producer 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.tools.command org.nuxeo.runtime.pubsub org.nuxeo.runtime.stream -
-
Uses of Name in org.nuxeo.ecm.core.bulk
Fields in org.nuxeo.ecm.core.bulk declared as Name Modifier and Type Field Description static NameBulkServiceImpl. COMMAND_STREAM_NAMEstatic NameBulkServiceImpl. DONE_STREAM_NAMEstatic NameBulkServiceImpl. STATUS_STREAM_NAME -
Uses of Name in org.nuxeo.ecm.core.work
Fields in org.nuxeo.ecm.core.work declared as Name Modifier and Type Field Description static NameWorkManagerImpl. DEAD_LETTER_QUEUEThe 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 Modifier and Type Field Description protected NameStreamServlet.CatParams. fromGroupprotected NameStreamServlet.CatParams. groupprotected NameStreamServlet.CatParams. stream -
Uses of Name in org.nuxeo.importer.stream.producer
Methods in org.nuxeo.importer.stream.producer that return Name Modifier and Type Method Description protected NameRandomDocumentMessageProducerFactory. getGroupName(int producerId) -
Uses of Name in org.nuxeo.lib.stream.computation
Fields in org.nuxeo.lib.stream.computation with type parameters of type Name Modifier and Type Field Description protected Map<Name,Codec<Record>>Settings. codecsprotected Map<Name,Integer>Settings. concurrenciesprotected Map<Name,Boolean>Settings. externalsprotected Map<Name,RecordFilterChain>Settings. filtersprotected Map<Name,Integer>Settings. partitionsprotected Map<Name,ComputationPolicy>Settings. policiesMethods in org.nuxeo.lib.stream.computation with parameters of type Name Modifier and Type Method Description SettingsSettings. addFilter(Name streamName, RecordFilter filter)Add a filterCodec<Record>Settings. getCodec(Name streamName)Gets the codec for a stream.intSettings. getConcurrency(Name computationName)RecordFilterChainSettings. getFilterChain(Name streamName)Gets the filter chain for a stream.intSettings. getPartitions(Name streamName)ComputationPolicySettings. getPolicy(Name computationName)Gets the policy for a computation.booleanSettings. isExternal(Name streamName)SettingsSettings. setCodec(Name streamName, Codec<Record> codec)Sets the codec for a stream.SettingsSettings. setConcurrency(Name computationName, int concurrency)SettingsSettings. setExternal(Name streamName, boolean external)SettingsSettings. setPartitions(Name streamName, int partitions)Sets the number of partitions for a stream.SettingsSettings. 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.booleanStreamProcessor. startComputation(Name computation)Start a computation thread pool that has been stopped usingStreamProcessor.stopComputation(Name)booleanStreamProcessor. 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 Name Modifier and Type Field Description protected Map<Name,RecordFilterChain>LogStreamManager. filtersprotected Set<Name>LogStreamManager. streamsMethods in org.nuxeo.lib.stream.computation.log with parameters of type Name Modifier and Type Method Description LogTailer<Record>LogStreamManager. createTailer(Name computationName, Collection<LogPartition> streamPartitions)RecordFilterLogStreamManager. getFilter(Name stream)protected voidLogStreamManager. initInternalStream(Name stream)booleanLogStreamProcessor. startComputation(Name computation)booleanLogStreamProcessor. stopComputation(Name computation)LogTailer<Record>LogStreamManager. subscribe(Name computationName, Collection<Name> streams, RebalanceListener listener)booleanLogStreamManager. supportSubscribe(Name stream)Returnstrueif 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 Name Modifier and Type Method Description protected Codec<Record>LogStreamManager. getCodec(Collection<Name> streams)LogTailer<Record>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 Name Modifier and Type Field Description protected NameLogPartition. nameMethods in org.nuxeo.lib.stream.log that return Name Modifier and Type Method Description NameNameResolver. getName(String id)NameLogTailer. group()Returns the consumer group.NameLogAppender. name()Returns the Log's name.NameLogPartition. name()Returns the Log's namestatic NameName. of(String namespace, String name)static NameName. ofId(String id)static NameName. ofUrn(String urn)Methods in org.nuxeo.lib.stream.log that return types with arguments of type Name Modifier and Type Method Description List<Name>LogManager. listAllNames()Returns all the Log names.List<Name>UnifiedLogManager. listAllNames()List<Name>LogManager. listConsumerGroups(Name name)List the consumer groups for a Log.List<Name>UnifiedLogManager. listConsumerGroups(Name name)Methods in org.nuxeo.lib.stream.log with parameters of type Name Modifier and Type Method Description booleanLogManager. createIfNotExists(Name name, int size)Creates a new Log withsizepartitions if the Log does not exists.booleanUnifiedLogManager. createIfNotExists(Name name, int size)default <M extends Externalizable>
LogTailer<M>LogManager. createTailer(Name group, Collection<LogPartition> partitions)Creates a tailer for a consumergroupand assign multiplepartitions.<M extends Externalizable>
LogTailer<M>LogManager. createTailer(Name group, Collection<LogPartition> partitions, Codec<M> codec)Creates a tailer for a consumergroupand assign multiplepartitions.default <M extends Externalizable>
LogTailer<M>LogManager. createTailer(Name group, LogPartition partition)Creates a tailer for a consumergroupand assign a singlepartition.default <M extends Externalizable>
LogTailer<M>LogManager. createTailer(Name group, LogPartition partition, Codec<M> codec)Creates a tailer for a consumergroupand assign a singlepartition.default <M extends Externalizable>
LogTailer<M>LogManager. createTailer(Name group, Name name)Creates a tailer for a consumergroupand assign allpartitionsof the Log.default <M extends Externalizable>
LogTailer<M>LogManager. createTailer(Name group, Name name, Codec<M> codec)Creates a tailer for a consumergroupand assigns allpartitionsof the Log.<M extends Externalizable>
LogTailer<M>UnifiedLogManager. createTailer(Name group, Collection<LogPartition> partitions, Codec<M> codec)booleanLogManager. delete(Name name)Tries to delete a Log.booleanUnifiedLogManager. delete(Name name)default voidLogManager. deleteRecords(Name name)Delete all records of a stream by moving the first offsets to end of each partition.voidUnifiedLogManager. deleteRecords(Name name)booleanLogManager. exists(Name name)Returnstrueif a Log with thisnameexists.booleanUnifiedLogManager. exists(Name name)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, usescodecto encode records.<M extends Externalizable>
LogAppender<M>UnifiedLogManager. getAppender(Name name, Codec<M> codec)StringNameResolver. getId(Name name)default LogLagLogManager. getLag(Name name, Name group)Returns the lag between consumergroupand producers for a Log.List<LogLag>LogManager. getLagPerPartition(Name name, Name group)Returns the lag between consumergroupand the producers for each partition.List<LogLag>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 consumergroupand 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 LogManagerUnifiedLogManager. getManager(Name name)protected LogManagerUnifiedLogManager. getManager(Name name, Name group)List<Name>LogManager. listConsumerGroups(Name name)List the consumer groups for a Log.List<Name>UnifiedLogManager. listConsumerGroups(Name name)booleanAbstractLogConfig. match(Name name)booleanAbstractLogConfig. match(Name name, Name group)booleanLogConfig. match(Name stream)booleanLogConfig. match(Name stream, Name group)static LogPartitionLogPartition. of(Name name, int partition)intLogManager. size(Name name)Returns the number of partition of a Log.intUnifiedLogManager. size(Name name)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Âgroupand subscribe to multiple Logs.<M extends Externalizable>
LogTailer<M>UnifiedLogManager. subscribe(Name group, Collection<Name> names, RebalanceListener listener, Codec<M> codec)booleanLogManager. supportSubscribe(Name stream)Returnstrueif 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.booleanUnifiedLogManager. supportSubscribe(Name stream)booleanLogAppender. waitFor(LogOffset offset, Name group, Duration timeout)Wait for consumer to process a message up to the offset.Method parameters in org.nuxeo.lib.stream.log with type arguments of type Name Modifier and Type Method Description 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Âgroupand 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 Constructor Description LogPartition(Name name, int partition) -
Uses of Name in org.nuxeo.lib.stream.log.chronicle
Fields in org.nuxeo.lib.stream.log.chronicle declared as Name Modifier and Type Field Description protected NameChronicleCompoundLogTailer. groupprotected NameChronicleLogAppender. nameMethods in org.nuxeo.lib.stream.log.chronicle that return Name Modifier and Type Method Description NameChronicleCompoundLogTailer. group()NameChronicleLogTailer. group()NameChronicleLogAppender. name()Methods in org.nuxeo.lib.stream.log.chronicle that return types with arguments of type Name Modifier and Type Method Description List<Name>ChronicleLogManager. listAllNames()List<Name>ChronicleLogManager. listConsumerGroups(Name name)Methods in org.nuxeo.lib.stream.log.chronicle with parameters of type Name 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 logvoidChronicleLogManager. create(Name name, int size)<M extends Externalizable>
CloseableLogAppender<M>ChronicleLogManager. createAppender(Name name, Codec<M> codec)LogTailer<M>ChronicleLogAppender. createTailer(LogPartition partition, Name group, Codec<M> codec)booleanChronicleLogManager. delete(Name name)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)booleanChronicleLogManager. exists(Name name)static booleanChronicleLogOffsetTracker. exists(Path basePath, Name group)protected ChronicleLogConfigChronicleLogManager. getConfig(Name name)protected ChronicleLogConfigChronicleLogManager. getConfig(Name name, Name group)protected LogLagChronicleLogManager. getLagForPartition(Name name, int partition, Name group)List<LogLag>ChronicleLogManager. getLagPerPartition(Name name, Name group)protected intChronicleLogManager. getSize(Name name)List<Name>ChronicleLogManager. listConsumerGroups(Name name)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)booleanChronicleLogAppender. waitFor(LogOffset offset, Name group, Duration timeout)Method parameters in org.nuxeo.lib.stream.log.chronicle with type arguments of type Name Modifier and Type Method Description protected <M extends Externalizable>
LogTailer<M>ChronicleLogManager. doSubscribe(Name group, Collection<Name> names, RebalanceListener listener, Codec<M> codec)Constructors in org.nuxeo.lib.stream.log.chronicle with parameters of type Name Constructor Description ChronicleCompoundLogTailer(Collection<ChronicleLogTailer<M>> tailers, Name group)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 LogChronicleLogOffsetTracker(String basePath, int partition, Name group, ChronicleRetentionDuration retention)ChronicleLogTailer(Codec<M> codec, String basePath, net.openhft.chronicle.queue.ExcerptTailer cqTailer, LogPartition partition, Name group, ChronicleRetentionDuration retention) -
Uses of Name in org.nuxeo.lib.stream.log.internals
Fields in org.nuxeo.lib.stream.log.internals declared as Name Modifier and Type Field Description protected static NameAbstractLogManager. ADMIN_GROUPNameLogPartitionGroup. groupNameLogPartitionGroup. nameFields in org.nuxeo.lib.stream.log.internals with type parameters of type Name Modifier and Type Field Description protected Map<Name,CloseableLogAppender>AbstractLogManager. appendersMethods in org.nuxeo.lib.stream.log.internals with parameters of type Name Modifier and Type Method Description protected voidAbstractLogManager. checkInvalidAssignment(Name group, LogPartition partition)protected abstract voidAbstractLogManager. create(Name name, int size)protected abstract <M extends Externalizable>
CloseableLogAppender<M>AbstractLogManager. createAppender(Name name, Codec<M> codec)booleanAbstractLogManager. createIfNotExists(Name name, int size)<M extends Externalizable>
LogTailer<M>AbstractLogManager. createTailer(Name group, Collection<LogPartition> partitions, Codec<M> codec)booleanAbstractLogManager. delete(Name name)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)abstract List<LogLag>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 intAbstractLogManager. getSize(Name name)intAbstractLogManager. size(Name name)<M extends Externalizable>
LogTailer<M>AbstractLogManager. subscribe(Name group, Collection<Name> names, RebalanceListener listener, Codec<M> codec)booleanAbstractLogManager. supportSubscribe(Name stream)Method parameters in org.nuxeo.lib.stream.log.internals with type arguments of type Name Modifier and Type Method Description protected 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 Name Constructor Description LogOffsetImpl(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 Name Modifier and Type Field Description protected NameKafkaLogTailer. groupprotected NameKafkaLogAppender. nameFields in org.nuxeo.lib.stream.log.kafka with type parameters of type Name Modifier and Type Field Description protected Collection<Name>KafkaLogTailer. namesMethods in org.nuxeo.lib.stream.log.kafka that return Name Modifier and Type Method Description NameKafkaLogTailer. group()NameKafkaLogAppender. name()Methods in org.nuxeo.lib.stream.log.kafka that return types with arguments of type Name Modifier and Type Method Description List<Name>KafkaLogManager. listAllNames()List<Name>KafkaLogManager. listConsumerGroups(Name name)Methods in org.nuxeo.lib.stream.log.kafka with parameters of type Name Modifier and Type Method Description protected static StringKafkaLogTailer. buildId(Name group, Collection<LogPartition> partitions)protected static StringKafkaLogTailer. buildSubscribeId(Name group, Collection<Name> names)voidKafkaLogManager. create(Name name, int size)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)booleanKafkaLogManager. delete(Name name)voidKafkaLogManager. 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)booleanKafkaLogManager. exists(Name name)protected KafkaLogConfigKafkaLogManager. getConfig(Name name)protected KafkaLogConfigKafkaLogManager. getConfig(Name name, Name group)List<LogLag>KafkaLogManager. getLagPerPartition(Name name, Name group)protected intKafkaLogManager. getSize(Name name)protected booleanKafkaLogAppender. isProcessed(Name group, org.apache.kafka.common.TopicPartition topicPartition, long offset)List<Name>KafkaLogManager. listConsumerGroups(Name name)static <M extends Externalizable>
KafkaLogAppender<M>KafkaLogAppender. open(Codec<M> codec, NameResolver resolver, Name name, Properties producerProperties, Properties consumerProperties)booleanKafkaLogManager. supportSubscribe(Name stream)booleanKafkaLogAppender. waitFor(LogOffset offset, Name group, Duration timeout)Method parameters in org.nuxeo.lib.stream.log.kafka with type arguments of type Name Modifier and Type Method Description protected static StringKafkaLogTailer. 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 Name Constructor Description KafkaLogTailer(Codec<M> codec, NameResolver resolver, Name group, Properties consumerProps) -
Uses of Name in org.nuxeo.lib.stream.pattern.consumer
Methods in org.nuxeo.lib.stream.pattern.consumer that return Name Modifier and Type Method Description NameConsumerPool. getConsumerGroupName() -
Uses of Name in org.nuxeo.lib.stream.tools.command
Fields in org.nuxeo.lib.stream.tools.command declared as Name Modifier and Type Field Description protected static NameRestoreCommand. GROUPprotected NameRestoreCommand. inputFields in org.nuxeo.lib.stream.tools.command with type parameters of type Name Modifier and Type Field Description protected List<Name>LatencyTrackerComputation. logNamesprotected List<Name>MonitorCommand. logNamesprotected List<Name>RestoreCommand. logNamesprotected List<Name>TrackerCommand. logNamesMethods in org.nuxeo.lib.stream.tools.command that return types with arguments of type Name Modifier and Type Method Description protected List<Name>MonitorCommand. getLogNames(LogManager manager, String names)protected List<Name>RestoreCommand. getLogNames(LogManager manager, String names)protected List<Name>TrackerCommand. getLogNames(LogManager manager, String names)Methods in org.nuxeo.lib.stream.tools.command with parameters of type Name Modifier and Type Method Description protected voidAppendCommand. append(LogManager manager, Name name, int partition, String codec, Path input)protected voidCatCommand. cat(LogManager manager, Name name, Name group, int limit, Renderer render, String codec)protected booleanCopyCommand. 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 voidDumpCommand. dump(LogManager manager, Name name, int partition, Name group, int limit, String codec, Path output)protected voidTailCommand. follow(LogManager manager, Name name, Name group, Renderer render, int timeout, String codec)protected LogLagPositionCommand. getLag(LogManager manager, Name group, Name name, int partition)protected LogTailer<Record>DumpCommand. getTailer(LogManager manager, Name name, int partition, Name group, String codec)protected StringPositionCommand. labelFor(Name name, int partition)protected voidLagCommand. lag(LogManager manager, Name name)protected voidLatencyCommand. latency(LogManager manager, Name name, Codec<Record> codec)protected booleanPositionCommand. positionAfterDate(LogManager manager, Name group, Name name, int partition, long timestamp)protected booleanPositionCommand. positionToOffset(LogManager manager, Name group, Name name, int partition, long offset)protected booleanPositionCommand. positionToWatermark(LogManager manager, Name group, Name name, int partition, long timestamp, String codec)protected voidLatencyDatadogComputation. publishMetrics(Latency latency, String prefix, String partition, Name stream, Name group)protected voidLagCommand. renderLag(Name group, List<LogLag> lags)protected voidLatencyCommand. renderLatency(Name group, List<Latency> latencies)protected booleanPositionCommand. reset(LogManager manager, Name group, Name name, int partition)protected voidTailCommand. tail(LogManager manager, Name name, Name group, int lines, Renderer render, String codec)protected booleanPositionCommand. toEnd(LogManager manager, Name group, Name name, int partition)protected voidWorkCatCommand. 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 Name 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 Name in org.nuxeo.runtime.pubsub
Fields in org.nuxeo.runtime.pubsub declared as Name Modifier and Type Field Description protected NameStreamPubSubProvider. logName -
Uses of Name in org.nuxeo.runtime.stream
Fields in org.nuxeo.runtime.stream with type parameters of type Name Modifier and Type Field Description protected Set<Name>StreamMetricsComputation. invalidStreamsprotected List<Name>StreamMetricsComputation. streamsMethods in org.nuxeo.runtime.stream that return Name Modifier and Type Method Description NameStreamMetricsComputation.LatencyMetric. getStream()Methods in org.nuxeo.runtime.stream that return types with arguments of type Name Modifier and Type Method Description protected List<Name>StreamMetricsComputation. getStreams()Methods in org.nuxeo.runtime.stream with parameters of type Name Modifier and Type Method Description booleanStreamService. restartComputation(Name computation)Restart the computation thread pool.booleanStreamServiceImpl. restartComputation(Name computation)booleanStreamService. setComputationPositionAfterDate(Name computation, Name stream, Instant dateTime)Moving computation position after a date.booleanStreamServiceImpl. setComputationPositionAfterDate(Name computation, Name stream, Instant after)booleanStreamService. setComputationPositionToBeginning(Name computation, Name stream)Moving computation position to the beginning of stream.booleanStreamServiceImpl. setComputationPositionToBeginning(Name computation, Name stream)booleanStreamService. setComputationPositionToEnd(Name computation, Name stream)Moving computation position to the end of stream.booleanStreamServiceImpl. setComputationPositionToEnd(Name computation, Name stream)booleanStreamService. setComputationPositionToOffset(Name computation, Name stream, int partition, long offset)Moving computation position to a specific offset for a partition.booleanStreamServiceImpl. setComputationPositionToOffset(Name computation, Name stream, int partition, long offset)booleanStreamService. stopComputation(Name computation)Stop computation thread pool immediately.booleanStreamServiceImpl. stopComputation(Name computation)
-