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 Name
BulkServiceImpl. COMMAND_STREAM_NAME
static Name
BulkServiceImpl. DONE_STREAM_NAME
static Name
BulkServiceImpl. 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 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 Modifier and Type Field Description protected Name
StreamServlet.CatParams. fromGroup
protected Name
StreamServlet.CatParams. group
protected Name
StreamServlet.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 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 Name Modifier and Type Field Description protected Map<Name,Codec<Record>>
Settings. codecs
protected Map<Name,Integer>
Settings. concurrencies
protected Map<Name,Boolean>
Settings. externals
protected Map<Name,RecordFilterChain>
Settings. filters
protected Map<Name,Integer>
Settings. partitions
protected Map<Name,ComputationPolicy>
Settings. policies
Methods in org.nuxeo.lib.stream.computation with parameters of type Name Modifier and Type Method Description Settings
Settings. addFilter(Name streamName, RecordFilter filter)
Add a filterCodec<Record>
Settings. getCodec(Name streamName)
Gets the codec for a stream.int
Settings. getConcurrency(Name computationName)
RecordFilterChain
Settings. getFilterChain(Name streamName)
Gets the filter chain for a stream.int
Settings. getPartitions(Name streamName)
ComputationPolicy
Settings. getPolicy(Name computationName)
Gets the policy for a computation.boolean
Settings. isExternal(Name streamName)
Settings
Settings. setCodec(Name streamName, Codec<Record> codec)
Sets the codec for a stream.Settings
Settings. setConcurrency(Name computationName, int concurrency)
Settings
Settings. setExternal(Name streamName, boolean external)
Settings
Settings. setPartitions(Name streamName, int partitions)
Sets the number of partitions for a stream.Settings
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 Name Modifier and Type Field Description protected Map<Name,RecordFilterChain>
LogStreamManager. filters
protected Set<Name>
LogStreamManager. streams
Methods 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)
RecordFilter
LogStreamManager. getFilter(Name stream)
protected void
LogStreamManager. initInternalStream(Name stream)
boolean
LogStreamProcessor. startComputation(Name computation)
boolean
LogStreamProcessor. stopComputation(Name computation)
LogTailer<Record>
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 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 Name
LogPartition. name
Methods in org.nuxeo.lib.stream.log that return Name Modifier and Type Method Description Name
NameResolver. getName(String id)
Name
LogTailer. group()
Returns the consumer group.Name
LogAppender. name()
Returns the Log's name.Name
LogPartition. name()
Returns the Log's namestatic Name
Name. of(String namespace, String name)
static Name
Name. ofId(String id)
static Name
Name. 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 boolean
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
LogManager. delete(Name name)
Tries to delete a Log.boolean
UnifiedLogManager. delete(Name name)
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
LogManager. exists(Name name)
Returnstrue
if a Log with thisname
exists.boolean
UnifiedLogManager. 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
, usescodec
to encode records.<M extends Externalizable>
LogAppender<M>UnifiedLogManager. getAppender(Name name, Codec<M> codec)
String
NameResolver. getId(Name name)
default LogLag
LogManager. getLag(Name name, Name group)
Returns the lag between consumergroup
and producers for a Log.List<LogLag>
LogManager. getLagPerPartition(Name name, Name group)
Returns the lag between consumergroup
and 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 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)
List<Name>
LogManager. listConsumerGroups(Name name)
List the consumer groups for a Log.List<Name>
UnifiedLogManager. listConsumerGroups(Name name)
boolean
AbstractLogConfig. match(Name name)
boolean
AbstractLogConfig. match(Name name, Name group)
boolean
LogConfig. match(Name stream)
boolean
LogConfig. match(Name stream, Name group)
static LogPartition
LogPartition. of(Name name, int partition)
int
LogManager. size(Name name)
Returns the number of partition of a Log.int
UnifiedLogManager. 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Â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
LogAppender. 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Â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 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 Name
ChronicleCompoundLogTailer. group
protected Name
ChronicleLogAppender. name
Methods in org.nuxeo.lib.stream.log.chronicle that return Name Modifier and Type Method Description Name
ChronicleCompoundLogTailer. group()
Name
ChronicleLogTailer. group()
Name
ChronicleLogAppender. 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 logvoid
ChronicleLogManager. 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)
boolean
ChronicleLogManager. 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)
boolean
ChronicleLogManager. exists(Name name)
static boolean
ChronicleLogOffsetTracker. exists(Path basePath, Name group)
protected ChronicleLogConfig
ChronicleLogManager. getConfig(Name name)
protected ChronicleLogConfig
ChronicleLogManager. getConfig(Name name, Name group)
protected LogLag
ChronicleLogManager. getLagForPartition(Name name, int partition, Name group)
List<LogLag>
ChronicleLogManager. getLagPerPartition(Name name, Name group)
protected int
ChronicleLogManager. 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)
boolean
ChronicleLogAppender. 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 Name
AbstractLogManager. ADMIN_GROUP
Name
LogPartitionGroup. group
Name
LogPartitionGroup. name
Fields in org.nuxeo.lib.stream.log.internals with type parameters of type Name Modifier and Type Field Description protected Map<Name,CloseableLogAppender>
AbstractLogManager. appenders
Methods in org.nuxeo.lib.stream.log.internals with parameters of type Name Modifier and Type Method Description protected void
AbstractLogManager. checkInvalidAssignment(Name group, LogPartition partition)
protected abstract void
AbstractLogManager. create(Name name, int size)
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
AbstractLogManager. 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 int
AbstractLogManager. getSize(Name name)
int
AbstractLogManager. size(Name name)
<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 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 Name
KafkaLogTailer. group
protected Name
KafkaLogAppender. name
Fields in org.nuxeo.lib.stream.log.kafka with type parameters of type Name Modifier and Type Field Description protected Collection<Name>
KafkaLogTailer. names
Methods in org.nuxeo.lib.stream.log.kafka that return Name Modifier and Type Method Description Name
KafkaLogTailer. group()
Name
KafkaLogAppender. 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 String
KafkaLogTailer. buildId(Name group, Collection<LogPartition> partitions)
protected static String
KafkaLogTailer. buildSubscribeId(Name group, Collection<Name> names)
void
KafkaLogManager. 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)
boolean
KafkaLogManager. delete(Name name)
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
KafkaLogManager. exists(Name name)
protected KafkaLogConfig
KafkaLogManager. getConfig(Name name)
protected KafkaLogConfig
KafkaLogManager. getConfig(Name name, Name group)
List<LogLag>
KafkaLogManager. getLagPerPartition(Name name, Name group)
protected int
KafkaLogManager. getSize(Name name)
protected boolean
KafkaLogAppender. 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)
boolean
KafkaLogManager. supportSubscribe(Name stream)
boolean
KafkaLogAppender. 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 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 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 Name
ConsumerPool. 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 Name
RestoreCommand. GROUP
protected Name
RestoreCommand. input
Fields in org.nuxeo.lib.stream.tools.command with type parameters of type Name Modifier and Type Field Description protected List<Name>
LatencyTrackerComputation. logNames
protected List<Name>
MonitorCommand. logNames
protected List<Name>
RestoreCommand. logNames
protected List<Name>
TrackerCommand. logNames
Methods 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 void
AppendCommand. append(LogManager manager, Name name, int partition, String codec, Path input)
protected void
CatCommand. cat(LogManager manager, Name name, Name group, int limit, Renderer render, String codec)
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)
protected LogTailer<Record>
DumpCommand. getTailer(LogManager manager, Name name, int partition, Name group, String codec)
protected String
PositionCommand. labelFor(Name name, int partition)
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
LagCommand. renderLag(Name group, List<LogLag> lags)
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 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 Name
StreamPubSubProvider. 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. invalidStreams
protected List<Name>
StreamMetricsComputation. streams
Methods in org.nuxeo.runtime.stream that return Name Modifier and Type Method Description Name
StreamMetricsComputation.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 boolean
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)
-