Uses of Class
org.nuxeo.lib.stream.computation.Record
-
-
Uses of Record in org.nuxeo.audit.storage.stream
Methods in org.nuxeo.audit.storage.stream with parameters of type Record Modifier and Type Method Description voidStreamAuditStorageWriter.AuditStorageLogWriterComputation. processRecord(ComputationContext context, String inputStreamName, Record record) -
Uses of Record in org.nuxeo.ecm.automation.core.operations.services.workmanager
Methods in org.nuxeo.ecm.automation.core.operations.services.workmanager with parameters of type Record Modifier and Type Method Description voidWorkManagerRunWorkInFailure.WorkFailureComputation. processRecord(ComputationContext context, String inputStreamName, Record record) -
Uses of Record in org.nuxeo.ecm.core.blob.stream
Fields in org.nuxeo.ecm.core.blob.stream with type parameters of type Record Modifier and Type Field Description protected List<Record>BlobDomainEventProducer. recordsMethods in org.nuxeo.ecm.core.blob.stream that return Record Modifier and Type Method Description protected RecordBlobDomainEventProducer. buildRecordFromEvent(String name, BlobEventContext ctx)Methods in org.nuxeo.ecm.core.blob.stream that return types with arguments of type Record Modifier and Type Method Description List<Record>BlobDomainEventProducer. getDomainEvents()Methods in org.nuxeo.ecm.core.blob.stream with parameters of type Record Modifier and Type Method Description voidStreamOrphanBlobGC.BlobGCComputation. processRecord(ComputationContext context, String inputStreamName, Record record) -
Uses of Record in org.nuxeo.ecm.core.bulk.action.computation
Methods in org.nuxeo.ecm.core.bulk.action.computation with parameters of type Record Modifier and Type Method Description voidAbstractBulkComputation. processRecord(ComputationContext context, String inputStreamName, Record record)voidExposeBlob. processRecord(ComputationContext context, String documentIdsStreamName, Record record)voidMakeBlob. processRecord(ComputationContext context, String documentIdsStreamName, Record record)voidSortBlob. processRecord(ComputationContext context, String inputStreamName, Record record)voidZipBlob. processRecord(ComputationContext context, String inputStreamName, Record record) -
Uses of Record in org.nuxeo.ecm.core.bulk.computation
Methods in org.nuxeo.ecm.core.bulk.computation with parameters of type Record Modifier and Type Method Description voidBulkScrollerComputation. processRecord(ComputationContext context, String inputStreamName, Record record)protected voidBulkScrollerComputation. processRecord(ComputationContext context, Record record)voidBulkStatusComputation. processRecord(ComputationContext context, String inputStreamName, Record record) -
Uses of Record in org.nuxeo.ecm.core.bulk.introspection
Methods in org.nuxeo.ecm.core.bulk.introspection with parameters of type Record Modifier and Type Method Description protected com.fasterxml.jackson.databind.JsonNodeStreamIntrospectionComputation. getJson(Record record)voidStreamIntrospectionComputation. processRecord(ComputationContext context, String inputStreamName, Record record) -
Uses of Record in org.nuxeo.ecm.core.event.stream
Methods in org.nuxeo.ecm.core.event.stream that return types with arguments of type Record Modifier and Type Method Description abstract List<Record>DomainEventProducer. getDomainEvents()Produces Domain Event Records from the accumulated Nuxeo Core events. -
Uses of Record in org.nuxeo.ecm.core.model.stream
Fields in org.nuxeo.ecm.core.model.stream with type parameters of type Record Modifier and Type Field Description protected List<Record>DocumentDomainEventProducer. recordsMethods in org.nuxeo.ecm.core.model.stream that return Record Modifier and Type Method Description protected RecordDocumentDomainEventProducer. buildRecordFromEvent(String eventName, DocumentDomainEventContext ctx)Methods in org.nuxeo.ecm.core.model.stream that return types with arguments of type Record Modifier and Type Method Description List<Record>DocumentDomainEventProducer. getDomainEvents()Methods in org.nuxeo.ecm.core.model.stream with parameters of type Record Modifier and Type Method Description voidStreamDocumentGC.DocumentGCComputation. processRecord(ComputationContext context, String inputStreamName, Record record) -
Uses of Record in org.nuxeo.ecm.core.work
Fields in org.nuxeo.ecm.core.work with type parameters of type Record Modifier and Type Field Description static Codec<Record>WorkManagerImpl. DEAD_LETTER_QUEUE_CODECMethods in org.nuxeo.ecm.core.work that return Record Modifier and Type Method Description RecordBaseOverflowRecordFilter. afterRead(Record record, LogOffset offset)RecordBaseOverflowRecordFilter. beforeAppend(Record record)Methods in org.nuxeo.ecm.core.work that return types with arguments of type Record Modifier and Type Method Description protected Codec<Record>StreamWorkManager. getCodec()Methods in org.nuxeo.ecm.core.work with parameters of type Record Modifier and Type Method Description RecordBaseOverflowRecordFilter. afterRead(Record record, LogOffset offset)RecordBaseOverflowRecordFilter. beforeAppend(Record record)protected StringBaseOverflowRecordFilter. getUniqRecordKey(Record record)voidWorkComputation. processRecord(ComputationContext context, String inputStreamName, Record record) -
Uses of Record in org.nuxeo.ecm.platform.audit.impl
Method parameters in org.nuxeo.ecm.platform.audit.impl with type arguments of type Record Modifier and Type Method Description voidStreamAuditWriter.AuditLogWriterComputation. batchFailure(ComputationContext context, String inputStreamName, List<Record> records)voidStreamAuditWriter.AuditLogWriterComputation. batchProcess(ComputationContext context, String inputStreamName, List<Record> records) -
Uses of Record in org.nuxeo.ecm.platform.audit.listener
Methods in org.nuxeo.ecm.platform.audit.listener that return Record Modifier and Type Method Description protected RecordStreamAuditEventListener. recordOf(String partitionKey, LogEntry entry)protected RecordStreamAuditEventListener. recordOf(LogEntry entry) -
Uses of Record in org.nuxeo.ecm.platform.audit.stream
Fields in org.nuxeo.ecm.platform.audit.stream with type parameters of type Record Modifier and Type Field Description protected List<Record>AuditDomainEventProducer. recordsMethods in org.nuxeo.ecm.platform.audit.stream that return Record Modifier and Type Method Description protected RecordAuditDomainEventProducer. buildRecordFromEvent(LogEntry entry)Methods in org.nuxeo.ecm.platform.audit.stream that return types with arguments of type Record Modifier and Type Method Description List<Record>AuditDomainEventProducer. getDomainEvents() -
Uses of Record in org.nuxeo.ecm.platform.video.computation
Fields in org.nuxeo.ecm.platform.video.computation declared as Record Modifier and Type Field Description protected RecordRecomputeVideoInfoComputation. recordMethods in org.nuxeo.ecm.platform.video.computation with parameters of type Record Modifier and Type Method Description voidRecomputeVideoInfoComputation. processRecord(ComputationContext context, String inputStreamName, Record record) -
Uses of Record in org.nuxeo.ecm.restapi.server.jaxrs.management
Methods in org.nuxeo.ecm.restapi.server.jaxrs.management that return types with arguments of type Record Modifier and Type Method Description protected LogTailer<Record>StreamServlet. createTailer(LogManager manager, StreamServlet.CatParams params)Method parameters in org.nuxeo.ecm.restapi.server.jaxrs.management with type arguments of type Record Modifier and Type Method Description voidSseRenderer. accept(LogRecord<Record> record) -
Uses of Record in org.nuxeo.elasticsearch.bulk
Methods in org.nuxeo.elasticsearch.bulk with parameters of type Record Modifier and Type Method Description voidBulkIndexComputation. processRecord(ComputationContext context, String inputStream, Record record)voidIndexCompletionComputation. processRecord(ComputationContext context, String inputStream, Record record) -
Uses of Record in org.nuxeo.lib.stream.computation
Fields in org.nuxeo.lib.stream.computation with type parameters of type Record Modifier and Type Field Description protected List<Record>AbstractBatchComputation. batchRecordsprotected Map<Name,Codec<Record>>Settings. codecsprotected Codec<Record>Settings. defaultCodecMethods in org.nuxeo.lib.stream.computation that return Record Modifier and Type Method Description default RecordRecordFilter. afterRead(Record record, LogOffset offset)Called after reading a record.default RecordRecordFilter. beforeAppend(Record record)Called before appending a record to a stream.static RecordRecord. of(String key, byte[] data)Creates a record using current timestamp and default flagMethods in org.nuxeo.lib.stream.computation that return types with arguments of type Record Modifier and Type Method Description Codec<Record>Settings. getCodec(String streamName)Gets the codec for a stream.Codec<Record>Settings. getCodec(Name streamName)Gets the codec for a stream.Methods in org.nuxeo.lib.stream.computation with parameters of type Record Modifier and Type Method Description default voidRecordFilter. afterAppend(Record record, LogOffset offset)Called after a record is appended to a stream.default RecordRecordFilter. afterRead(Record record, LogOffset offset)Called after reading a record.LogOffsetStreamManager. append(String stream, Record record)Appends a record to a processor's source stream.default RecordRecordFilter. beforeAppend(Record record)Called before appending a record to a stream.voidAbstractBatchComputation. processRecord(ComputationContext context, String inputStreamName, Record record)voidComputation. processRecord(ComputationContext context, String inputStreamName, Record record)Process an incoming record on one of the computation's input streams.voidComputationContext. produceRecord(String streamName, Record record)Method parameters in org.nuxeo.lib.stream.computation with type arguments of type Record Modifier and Type Method Description abstract voidAbstractBatchComputation. batchFailure(ComputationContext context, String inputStreamName, List<Record> records)Called when the retry policy has failed.protected abstract voidAbstractBatchComputation. batchProcess(ComputationContext context, String inputStreamName, List<Record> records)Called when: the batch capacity is reached the time threshold is reached the inputStreamName has changed If this method raises an exception the retry policy is applied.SettingsSettings. setCodec(String streamName, Codec<Record> codec)Sets the codec for a stream.SettingsSettings. setCodec(Name streamName, Codec<Record> codec)Sets the codec for a stream.Constructor parameters in org.nuxeo.lib.stream.computation with type arguments of type Record Constructor Description Settings(int defaultConcurrency, int defaultPartitions, Codec<Record> defaultCodec)Default concurrency and partition to use if not specified explicitly.Settings(int defaultConcurrency, int defaultPartitions, Codec<Record> defaultCodec, ComputationPolicy defaultPolicy)Settings(int defaultConcurrency, int defaultPartitions, Codec<Record> defaultCodec, ComputationPolicy defaultPolicy, RecordFilterChain defaultFilter)Settings(int defaultConcurrency, int defaultPartitions, Codec<Record> defaultCodec, ComputationPolicy defaultPolicy, RecordFilterChain defaultFilter, boolean defaultExternal) -
Uses of Record in org.nuxeo.lib.stream.computation.internals
Fields in org.nuxeo.lib.stream.computation.internals with type parameters of type Record Modifier and Type Field Description protected Map<String,List<Record>>ComputationContextImpl. streamRecordsMethods in org.nuxeo.lib.stream.computation.internals that return Record Modifier and Type Method Description RecordRecordFilterChainImpl. afterRead(Record record, LogOffset offset)RecordRecordFilterChainImpl. beforeAppend(Record record)Methods in org.nuxeo.lib.stream.computation.internals that return types with arguments of type Record Modifier and Type Method Description List<Record>ComputationContextImpl. getRecords(String streamName)Methods in org.nuxeo.lib.stream.computation.internals with parameters of type Record Modifier and Type Method Description voidRecordFilterChainImpl. afterAppend(Record record, LogOffset offset)RecordRecordFilterChainImpl. afterRead(Record record, LogOffset offset)RecordRecordFilterChainImpl. beforeAppend(Record record)voidComputationContextImpl. produceRecord(String streamName, Record record)LogOffsetComputationContextImpl. produceRecordImmediate(String streamName, Record record)Writes to an output stream immediately. -
Uses of Record in org.nuxeo.lib.stream.computation.log
Fields in org.nuxeo.lib.stream.computation.log with type parameters of type Record Modifier and Type Field Description static Codec<Record>LogStreamManager. INTERNAL_CODECprotected LogTailer<Record>ComputationRunner. tailerMethods in org.nuxeo.lib.stream.computation.log that return types with arguments of type Record Modifier and Type Method Description LogTailer<Record>LogStreamManager. createTailer(Name computationName, Collection<LogPartition> streamPartitions)protected Codec<Record>LogStreamManager. getCodec(Collection<Name> streams)protected Codec<Record>LogStreamProcessor. getCodecForStreams(String name, Set<String> streams)LogTailer<Record>LogStreamManager. subscribe(Name computationName, Collection<Name> streams, RebalanceListener listener)Methods in org.nuxeo.lib.stream.computation.log with parameters of type Record Modifier and Type Method Description LogOffsetLogStreamManager. append(String streamUrn, Record record)protected voidComputationRunner. checkRecordFlags(Record record)protected io.opencensus.trace.SpanComputationRunner. getSpanFromRecord(Record record)protected voidComputationRunner. processRecordWithRetry(String from, Record record)protected voidComputationRunner. processRecordWithTracing(String from, Record record) -
Uses of Record in org.nuxeo.lib.stream.tools.command
Fields in org.nuxeo.lib.stream.tools.command with type parameters of type Record Modifier and Type Field Description protected Codec<Record>LatencyTrackerComputation. codecMethods in org.nuxeo.lib.stream.tools.command that return types with arguments of type Record Modifier and Type Method Description protected Codec<Record>Command. getRecordCodec(String codec)protected LogTailer<Record>DumpCommand. getTailer(LogManager manager, Name name, int partition, Name group, String codec)Methods in org.nuxeo.lib.stream.tools.command with parameters of type Record Modifier and Type Method Description voidLatencyTrackerComputation. processRecord(ComputationContext context, String inputStreamName, Record record)Method parameters in org.nuxeo.lib.stream.tools.command with type arguments of type Record Modifier and Type Method Description protected voidLatencyCommand. latency(LogManager manager, Codec<Record> codec)protected voidLatencyCommand. latency(LogManager manager, Name name, Codec<Record> codec)protected LogOffsetPositionCommand. searchWatermarkOffset(LogTailer<Record> tailer, long timestamp)Constructor parameters in org.nuxeo.lib.stream.tools.command with type arguments of type Record 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 Record in org.nuxeo.lib.stream.tools.renderer
Methods in org.nuxeo.lib.stream.tools.renderer with parameters of type Record Modifier and Type Method Description protected StringRenderer. renderAvroMessage(AvroSchemaStore store, Record record)protected StringRenderer. tryToRenderAvroData(AvroSchemaStore store, Record record)Method parameters in org.nuxeo.lib.stream.tools.renderer with type arguments of type Record Modifier and Type Method Description voidMarkdownRenderer. accept(LogRecord<Record> record)voidTextRenderer. accept(LogRecord<Record> record) -
Uses of Record in org.nuxeo.runtime.codec
Classes in org.nuxeo.runtime.codec with type parameters of type Record Modifier and Type Class Description classAvroRecordCodec<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 Record in org.nuxeo.runtime.pubsub
Fields in org.nuxeo.runtime.pubsub with type parameters of type Record Modifier and Type Field Description protected LogAppender<Record>StreamPubSubProvider. appenderprotected Codec<Record>StreamPubSubProvider. codec -
Uses of Record in org.nuxeo.runtime.stream
Fields in org.nuxeo.runtime.stream with type parameters of type Record Modifier and Type Field Description protected Codec<Record>StreamMetricsComputation. codecMethods in org.nuxeo.runtime.stream with parameters of type Record Modifier and Type Method Description voidStreamMetricsComputation. processRecord(ComputationContext context, String inputStreamName, Record record)Method parameters in org.nuxeo.runtime.stream with type arguments of type Record Modifier and Type Method Description booleanStreamMetricsComputation.LatencyMetric. update(LogManager manager, Codec<Record> codec)
-