github.com/apache/storm:storm-client/src/jvm/org/apache/storm/trident/Stream.java: [ master, ] |
---|
98: public class Stream implements IAggregatableStream, ResourceDeclarer<Stream> {
|
103: protected Stream(TridentTopology topology, String name, Node node) {
|
592: private <T> Stream comparableAggregateStream(String inputFieldName, Aggregator<T> aggregator) {
|
807: public Stream toStream() {
|
85: * A Stream represents the core data model in Trident, and can be thought of as a "stream" of tuples that are p...(29 bytes skipped)...
|
115: public Stream name(String name) {
|
116: return new Stream(topology, name, node);
|
122: public Stream parallelismHint(int hint) {
|
131: public Stream setCPULoad(Number load) {
|
140: public Stream setMemoryLoad(Number onHeap) {
|
149: public Stream setMemoryLoad(Number onHeap, Number offHeap) {
|
155: public Stream addSharedMemory(SharedMemory request) {
|
161: * Filters out fields from a stream, resulting in a Stream containing only the fields specified by `keepFields`.
|
163: * <p>For example, if you had a Stream `mystream` containing the fields `["a", "b", "c","d"]`, calling"
|
169: * @param keepFields The fields in the Stream to keep
|
171: public Stream project(Fields keepFields) {
|
192: public Stream partitionBy(Fields fields) {
|
200: public Stream partition(CustomStreamGrouping partitioner) {
|
209: public Stream partition(Grouping grouping) {
|
222: public Stream shuffle() {
|
231: public Stream localOrShuffle() {
|
241: public Stream global() {
|
252: public Stream batchGlobal() {
|
263: public Stream broadcast() {
|
270: public Stream identityPartition() {
|
275: * Applies an `Assembly` to this `Stream`.
|
279: public Stream applyAssembly(Assembly assembly) {
|
284: public Stream each(Fields inputFields, Function function, Fields functionFields) {
|
294: public Stream each(Function function, Fields functionFields) {
|
298: public Stream each(Fields inputFields, Filter filter) {
|
304: public Stream partitionAggregate(Fields inputFields, Aggregator agg, Fields functionFields) {
|
314: public Stream partitionAggregate(Aggregator agg, Fields functionFields) {
|
318: public Stream partitionAggregate(CombinerAggregator agg, Fields functionFields) {
|
322: public Stream partitionAggregate(Fields inputFields, CombinerAggregator agg, Fields functionFields) {
|
329: public Stream partitionAggregate(ReducerAggregator agg, Fields functionFields) {
|
333: public Stream partitionAggregate(Fields inputFields, ReducerAggregator agg, Fields functionFields) {
|
340: public Stream stateQuery(TridentState state, Fields inputFields, QueryFunction function, Fields functionFields) {...(0 bytes skipped)...
|
352: public Stream stateQuery(TridentState state, QueryFunction function, Fields functionFields) {
|
403: public Stream filter(Filter filter) {
|
414: public Stream filter(Fields inputFields, Filter filter) {
|
424: public Stream map(MapFunction function) {
|
442: public Stream map(MapFunction function, Fields outputFields) {
|
460: public Stream flatMap(FlatMapFunction function) {
|
480: public Stream flatMap(FlatMapFunction function, Fields outputFields) {
|
498: public Stream peek(Consumer action) {
|
520: public Stream minBy(String inputFieldName) {
|
535: public <T> Stream minBy(String inputFieldName, Comparator<T> comparator) {
|
547: public Stream min(Comparator<TridentTuple> comparator) {
|
560: public Stream maxBy(String inputFieldName) {
|
575: public <T> Stream maxBy(String inputFieldName, Comparator<T> comparator) {
|
587: public Stream max(Comparator<TridentTuple> comparator) {
|
599: public Stream aggregate(Aggregator agg, Fields functionFields) {
|
603: public Stream aggregate(Fields inputFields, Aggregator agg, Fields functionFields) {
|
610: public Stream aggregate(CombinerAggregator agg, Fields functionFields) {
|
614: public Stream aggregate(Fields inputFields, CombinerAggregator agg, Fields functionFields) {
|
621: public Stream aggregate(ReducerAggregator agg, Fields functionFields) {
|
625: public Stream aggregate(Fields inputFields, ReducerAggregator agg, Fields functionFields) {
|
642: public Stream tumblingWindow(int windowCount, WindowsStoreFactory windowStoreFactory,
|
657: public Stream tumblingWindow(BaseWindowedBolt.Duration windowDuration, WindowsStoreFactory windowStoreFactory,
|
674: public Stream slidingWindow(int windowCount, int slideCount, WindowsStoreFactory windowStoreFactory,
|
691: public Stream slidingWindow(BaseWindowedBolt.Duration windowDuration, BaseWindowedBolt.Duration slidingInterval,
|
706: public Stream window(WindowConfig windowConfig, Fields inputFields, Aggregator aggregator, Fields functionFields)...(2 bytes skipped)...
|
723: public Stream window(WindowConfig windowConfig, WindowsStoreFactory windowStoreFactory, Fields inputFields,
|
728: private Stream window(WindowConfig windowConfig, WindowsStoreFactory windowStoreFactory, Fields inputFields, Aggre...(17 bytes skipped)...
|
737: Stream stream = topology.addSourcedNode(this,
|
748: Stream effectiveStream = stream.project(functionFields);
|
830: static class BatchGlobalAggScheme implements GlobalAggregationScheme<Stream> {
|
833: public IAggregatableStream aggPartition(Stream s) {
|
844: static class GlobalAggScheme implements GlobalAggregationScheme<Stream> {
|
847: public IAggregatableStream aggPartition(Stream s) {
|
26: import org.apache.storm.trident.fluent.GroupedStream;
|
27: import org.apache.storm.trident.fluent.IAggregatableStream;
|
184: public GroupedStream groupBy(Fields fields) {
|
186: return new GroupedStream(this, fields);
|
522: return comparableAggregateStream(inputFieldName, min);
|
537: return comparableAggregateStream(inputFieldName, min);
|
549: return comparableAggregateStream(null, min);
|
562: return comparableAggregateStream(inputFieldName, max);
|
577: return comparableAggregateStream(inputFieldName, max);
|
589: return comparableAggregateStream(null, max);
|
756: return effectiveStream;
|
21: import org.apache.storm.grouping.CustomStreamGrouping;
|
174: new ProcessorNode(topology.getUniqueStreamId(),
|
207: ...(17 bytes skipped)...thod takes in a custom partitioning function that implements {@link org.apache.storm.grouping.CustomStreamGrouping}
|
287: new ProcessorNode(topology.getUniqueStreamId(),
|
307: new ProcessorNode(topology.getUniqueStreamId(),
|
343: Node n = new ProcessorNode(topology.getUniqueStreamId(),
|
363: ProcessorNode n = new ProcessorNode(topology.getUniqueStreamId(),
|
427: new ProcessorNode(topology.getUniqueStreamId(),
|
445: new ProcessorNode(topology.getUniqueStreamId(),
|
463: new ProcessorNode(topology.getUniqueStreamId(),
|
483: new ProcessorNode(topology.getUniqueStreamId(),
|
501: new ProcessorNode(topology.getUniqueStreamId(),
|
738: new ProcessorNode(topology.getUniqueStreamId(),
|
chromium.googlesource.com/native_client/pnacl-llvm:include/llvm/Bitcode/NaCl/NaClObjDumpStream.h: [ master, ] |
---|
925: raw_ostream &Stream;
|
339: raw_ostream &BaseStream;
|
343: raw_string_ostream TextStream;
|
761: class ObjDumpStream {
|
788: ~ObjDumpStream() { Flush(); }
|
939: raw_string_ostream AssemblyStream;
|
943: raw_string_ostream MessageStream;
|
952: raw_string_ostream RecordStream;
|
207: /// Base Stream. The viewing width is defined by LineWidth. The
|
521: inline raw_ostream &operator<<(raw_ostream &Stream,
|
526: assert(&Stream == &Directive.GetFormatter().Tokens());
|
528: return Stream;
|
780: /// comments and errors into a single (user proved Stream). When
|
786: ObjDumpStream(raw_ostream &Stream, bool DumpRecords, bool DumpAssembly);
|
1: //===- NaClObjDumpStream.h --------------------------------------*- C++ -*-===//
|
210: explicit TextFormatter(raw_ostream &BaseStream,
|
219: return TextStream;
|
664: class ObjDumpStream;
|
670: /// The formatter used for dumping records in ObjDumpStream.
|
679: explicit RecordTextFormatter(ObjDumpStream *ObjDump);
|
762: ObjDumpStream(const ObjDumpStream&) = delete;
|
763: void operator=(const ObjDumpStream&) = delete;
|
793: return AssemblyStream;
|
799: return RecordStream;
|
805: return MessageStream;
|
skia.googlesource.com/third_party/poppler:poppler/Stream.h: [ master, ] |
---|
96: class Stream {
|
765: class ASCII85Stream: public FilterStream {
|
51: enum StreamKind {
|
67: enum StreamColorSpaceMode {
|
222: virtual Stream *getNextStream() { return nullptr; }
|
249: class OutStream {
|
275: class FileOutStream : public OutStream {
|
301: class BaseStream: public Stream {
|
312: BaseStream *getBaseStream() override { return this; }
|
313: Stream *getUndecodedStream() override { return this; }
|
335: class FilterStream: public Stream {
|
343: BaseStream *getBaseStream() override { return str->getBaseStream(); }
|
344: Stream *getUndecodedStream() override { return str->getUndecodedStream(); }
|
347: Stream *getNextStream() override { return str; }
|
361: class ImageStream {
|
408: class StreamPredictor {
|
450: class FileStream: public BaseStream {
|
525: class CachedFileStream: public BaseStream {
|
570: class BaseMemStream: public BaseStream {
|
573: BaseMemStream(T *bufA, Goffset startA, Goffset lengthA, Object &&dictA) : BaseStream(std::move(dictA), lengthA) {
|
585: Stream *makeSubStream(Goffset startA, bool limited, Goffset lengthA, Object &&dictA) override {
|
668: class MemStream : public BaseMemStream<const char>
|
671: MemStream(const char *bufA, Goffset startA, Goffset lengthA, Object &&dictA)
|
676: class AutoFreeMemStream : public BaseMemStream<char>
|
679: AutoFreeMemStream(char *bufA, Goffset startA, Goffset lengthA, Object &&dictA)
|
683: ~AutoFreeMemStream()
|
698: class EmbedStream: public BaseStream {
|
742: class ASCIIHexStream: public FilterStream {
|
790: class LZWStream: public FilterStream {
|
850: class RunLengthStream: public FilterStream {
|
883: class CCITTFaxStream: public FilterStream {
|
971: class DCTStream: public FilterStream {
|
1078: class FlateStream: public FilterStream {
|
1153: class EOFStream: public FilterStream {
|
1170: class BufStream: public FilterStream {
|
448: #define fileStreamBufSize 256
|
523: #define cachedStreamBufSize 1024
|
3: // Stream.h
|
76: // This is in Stream.h instead of Decrypt.h to avoid really annoying
|
93: // Stream (base class)
|
100: Stream();
|
103: virtual ~Stream();
|
105: Stream(const Stream &) = delete;
|
106: Stream& operator=(const Stream &other) = delete;
|
208: virtual Stream *getUndecodedStream() = 0;
|
226: Stream *addFilters(Dict *dict, int recursion = 0);
|
238: Stream *makeFilter(const char *name, Stream *str, Object *params, int recursion = 0, Dict *dict = nullptr);
|
308: virtual Stream *makeSubStream(Goffset start, bool limited,
|
338: FilterStream(Stream *strA);
|
354: Stream *str;
|
367: ImageStream(Stream *strA, int widthA, int nCompsA, int nBitsA);
|
393: Stream *str; // base stream
|
413: StreamPredictor(Stream *strA, int predictorA,
|
431: Stream *str; // base stream
|
457: Stream *makeSubStream(Goffset startA, bool limitedA,
|
532: Stream *makeSubStream(Goffset startA, bool limitedA,
|
701: EmbedStream(Stream *strA, Object &&dictA, bool limitedA, Goffset lengthA, bool reusableA = false);
|
704: Stream *makeSubStream(Goffset start, bool limitedA,
|
726: Stream *str;
|
745: ASCIIHexStream(Stream *strA);
|
762: // ASCII85Stream
|
768: ASCII85Stream(Stream *strA);
|
769: ~ASCII85Stream();
|
793: LZWStream(Stream *strA, int predictor, int columns, int colors,
|
853: RunLengthStream(Stream *strA);
|
886: CCITTFaxStream(Stream *strA, int encodingA, bool endOfLineA,
|
974: DCTStream(Stream *strA, int colorXformA, Dict *dict, int recursion);
|
1081: FlateStream(Stream *strA, int predictor, int columns,
|
1156: EOFStream(Stream *strA);
|
1173: BufStream(Stream *strA, int bufSizeA);
|
1198: FixedLengthEncoder(Stream *strA, int lengthA);
|
1221: ASCIIHexEncoder(Stream *strA);
|
1251: ASCII85Encoder(Stream *strA);
|
1281: RunLengthEncoder(Stream *strA);
|
1317: LZWEncoder(Stream *strA);
|
1349: CMYKGrayEncoder(Stream *strA);
|
1378: RGBGrayEncoder(Stream *strA);
|
46: class BaseStream;
|
109: virtual StreamKind getKind() = 0;
|
174: // This is only used by StreamPredictor.
|
203: // Get the BaseStream of this stream.
|
204: virtual BaseStream *getBaseStream() = 0;
|
206: // Get the stream after the last decoder (this may be a BaseStream
|
207: // or a DecryptStream).
|
219: StreamColorSpaceMode * /*csMode*/) {}
|
245: // OutStream
|
252: OutStream ();
|
255: virtual ~OutStream ();
|
257: OutStream(const OutStream &) = delete;
|
258: OutStream& operator=(const OutStream &other) = delete;
|
273: // FileOutStream
|
277: FileOutStream (FILE* fa, Goffset startA);
|
279: ~FileOutStream ();
|
296: // BaseStream
|
305: BaseStream(Object &&dictA, Goffset lengthA);
|
306: ~BaseStream();
|
307: virtual BaseStream *copy() = 0;
|
330: // FilterStream
|
339: ~FilterStream();
|
358: // ImageStream
|
369: ~ImageStream();
|
371: ImageStream(const ImageStream &) = delete;
|
372: ImageStream& operator=(const ImageStream &other) = delete;
|
405: // StreamPredictor
|
416: ~StreamPredictor();
|
418: StreamPredictor(const StreamPredictor &) = delete;
|
419: StreamPredictor& operator=(const StreamPredictor &) = delete;
|
445: // FileStream
|
453: FileStream(GooFile* fileA, Goffset startA, bool limitedA,
|
455: ~FileStream();
|
456: BaseStream *copy() override;
|
459: StreamKind getKind() override { return strFile; }
|
520: // CachedFileStream
|
528: CachedFileStream(CachedFile *ccA, Goffset startA, bool limitedA,
|
530: ~CachedFileStream();
|
531: BaseStream *copy() override;
|
534: StreamKind getKind() override { return strCachedFile; }
|
566: // MemStream
|
581: BaseStream *copy() override {
|
582: return new BaseMemStream(buf, start, length, dict.copy());
|
593: return new BaseMemStream(buf, startA, newLength, std::move(dictA));
|
596: StreamKind getKind() override { return strWeird; }
|
672: : BaseMemStream(bufA, startA, lengthA, std::move(dictA))
|
680: : BaseMemStream(bufA, startA, lengthA, std::move(dictA))
|
689: // EmbedStream
|
693: // EmbedStream is deleted, reads from the base stream will proceed where
|
694: // the BaseStream left off. Note that this is very different behavior
|
695: // that creating a new FileStream (using makeSubStream).
|
702: ~EmbedStream();
|
703: BaseStream *copy() override;
|
706: StreamKind getKind() override { return str->getKind(); }
|
739: // ASCIIHexStream
|
746: ~ASCIIHexStream();
|
747: StreamKind getKind() override { return strASCIIHex; }
|
770: StreamKind getKind() override { return strASCII85; }
|
787: // LZWStream
|
795: ~LZWStream();
|
796: StreamKind getKind() override { return strLZW; }
|
822: StreamPredictor *pred; // predictor
|
847: // RunLengthStream
|
854: ~RunLengthStream();
|
855: StreamKind getKind() override { return strRunLength; }
|
878: // CCITTFaxStream
|
889: ~CCITTFaxStream();
|
890: StreamKind getKind() override { return strCCITTFax; }
|
942: // DCTStream
|
975: virtual ~DCTStream();
|
976: StreamKind getKind() override { return strDCT; }
|
1051: // FlateStream
|
1083: ~FlateStream();
|
1084: StreamKind getKind() override { return strFlate; }
|
1113: StreamPredictor *pred; // predictor
|
1150: // EOFStream
|
1157: ~EOFStream();
|
1158: StreamKind getKind() override { return strWeird; }
|
1167: // BufStream
|
1174: ~BufStream();
|
1175: StreamKind getKind() override { return strWeird; }
|
1195: class FixedLengthEncoder: public FilterStream {
|
1200: StreamKind getKind() override { return strWeird; }
|
1218: class ASCIIHexEncoder: public FilterStream {
|
1223: StreamKind getKind() override { return strWeird; }
|
1248: class ASCII85Encoder: public FilterStream {
|
1253: StreamKind getKind() override { return strWeird; }
|
1278: class RunLengthEncoder: public FilterStream {
|
1283: StreamKind getKind() override { return strWeird; }
|
1314: class LZWEncoder: public FilterStream {
|
1319: StreamKind getKind() override { return strWeird; }
|
1346: class CMYKGrayEncoder: public FilterStream {
|
1351: StreamKind getKind() override { return strWeird; }
|
1375: class RGBGrayEncoder: public FilterStream {
|
1380: StreamKind getKind() override { return strWeird; }
|
509: char buf[fileStreamBufSize];
|
515: bool needsEncryptionOnSave; // Needed for FileStreams that point to "external" files
|
556: char buf[cachedStreamBufSize];
|
skia.googlesource.com/third_party/poppler:poppler/Stream.cc: [ master, ] |
---|
92: Stream::Stream() {
|
1178: ASCII85Stream::ASCII85Stream(Stream *strA):
|
1184: ASCII85Stream::~ASCII85Stream() {
|
178: class BaseStreamStream : public Stream
|
181: BaseStreamStream(Stream *strA) : str(strA)
|
194: BaseStream *getBaseStream() override { return str->getBaseStream()->getBaseStream(); }
|
195: Stream *getUndecodedStream() override { return str->getBaseStream()->getUndecodedStream(); }
|
353: OutStream::OutStream ()
|
357: OutStream::~OutStream ()
|
364: FileOutStream::FileOutStream (FILE* fa, Goffset startA)
|
370: FileOutStream::~FileOutStream ()
|
403: BaseStream::BaseStream(Object &&dictA, Goffset lengthA) {
|
408: BaseStream::~BaseStream() {
|
415: FilterStream::FilterStream(Stream *strA) {
|
419: FilterStream::~FilterStream() {
|
434: ImageStream::ImageStream(Stream *strA, int widthA, int nCompsA, int nBitsA) {
|
464: ImageStream::~ImageStream() {
|
554: StreamPredictor::StreamPredictor(Stream *strA, int predictorA,
|
752: FileStream::FileStream(GooFile* fileA, Goffset startA, bool limitedA,
|
766: FileStream::~FileStream() {
|
774: Stream *FileStream::makeSubStream(Goffset startA, bool limitedA,
|
844: CachedFileStream::CachedFileStream(CachedFile *ccA, Goffset startA,
|
858: CachedFileStream::~CachedFileStream()
|
869: Stream *CachedFileStream::makeSubStream(Goffset startA, bool limitedA,
|
948: EmbedStream::EmbedStream(Stream *strA, Object &&dictA,
|
965: EmbedStream::~EmbedStream() {
|
975: Stream *EmbedStream::makeSubStream(Goffset start, bool limitedA,
|
1086: ASCIIHexStream::ASCIIHexStream(Stream *strA):
|
1092: ASCIIHexStream::~ASCIIHexStream() {
|
1259: LZWStream::LZWStream(Stream *strA, int predictor, int columns, int colors,
|
1277: LZWStream::~LZWStream() {
|
1472: RunLengthStream::RunLengthStream(Stream *strA):
|
1478: RunLengthStream::~RunLengthStream() {
|
1556: CCITTFaxStream::CCITTFaxStream(Stream *strA, int encodingA, bool endOfLineA,
|
1595: CCITTFaxStream::~CCITTFaxStream() {
|
2408: DCTStream::DCTStream(Stream *strA, int colorXformA, Dict *dict, int recursion):
|
2437: DCTStream::~DCTStream() {
|
4478: FlateStream::FlateStream(Stream *strA, int predictor, int columns,
|
4495: FlateStream::~FlateStream() {
|
4947: EOFStream::EOFStream(Stream *strA):
|
4951: EOFStream::~EOFStream() {
|
4959: BufStream::BufStream(Stream *strA, int bufSizeA): FilterStream(strA) {
|
4964: BufStream::~BufStream() {
|
581: StreamPredictor::~StreamPredictor() {
|
3: // Stream.cc
|
64: #include "Stream.h"
|
66: #include "JBIG2Stream.h"
|
67: #include "Stream-CCITT.h"
|
79: #include "JPEG2000Stream.h"
|
89: // Stream (base class)
|
96: Stream::~Stream() = default;
|
98: void Stream::close() {
|
101: int Stream::getRawChar() {
|
106: int Stream::getChars(int nChars, unsigned char *buffer) {
|
111: void Stream::getRawChars(int nChars, int *buffer) {
|
115: char *Stream::getLine(char *buf, int size) {
|
136: GooString *Stream::getPSFilter(int psLevel, const char *indent) {
|
140: Stream *Stream::addFilters(Dict *dict, int recursion) {
|
143: Stream *str;
|
200: std::unique_ptr<Stream> str;
|
203: Stream *Stream::makeFilter(const char *name, Stream *str, Object *params, int recursion, Dict *dict) {
|
216: str = new ASCII85Stream(str);
|
329: str = new JBIG2Stream(str, std::move(globals), &obj);
|
1175: // ASCII85Stream
|
1188: void ASCII85Stream::reset() {
|
1194: int ASCII85Stream::lookChar() {
|
1238: GooString *ASCII85Stream::getPSFilter(int psLevel, const char *indent) {
|
1251: bool ASCII85Stream::isBinary(bool last) {
|
5005: FixedLengthEncoder::FixedLengthEncoder(Stream *strA, int lengthA):
|
5042: ASCIIHexEncoder::ASCIIHexEncoder(Stream *strA):
|
5089: ASCII85Encoder::ASCII85Encoder(Stream *strA):
|
5181: RunLengthEncoder::RunLengthEncoder(Stream *strA):
|
5286: LZWEncoder::LZWEncoder(Stream *strA):
|
5431: CMYKGrayEncoder::CMYKGrayEncoder(Stream *strA):
|
5474: RGBGrayEncoder::RGBGrayEncoder(Stream *strA):
|
71: #include "DCTStream.h"
|
75: #include "FlateStream.h"
|
81: #include "JPXStream.h"
|
168: str = new EOFStream(str);
|
185: StreamKind getKind() override { return str->getBaseStream()->getKind(); }
|
186: void reset() override { str->getBaseStream()->reset(); }
|
187: int getChar() override { return str->getBaseStream()->getChar(); }
|
188: int lookChar() override { return str->getBaseStream()->lookChar(); }
|
189: bool isBinary(bool last = true) override { return str->getBaseStream()->isBinary(); }
|
190: int getUnfilteredChar () override { return str->getBaseStream()->getUnfilteredChar(); }
|
191: void unfilteredReset () override { str->getBaseStream()->unfilteredReset(); }
|
192: Goffset getPos() override { return str->getBaseStream()->getPos(); }
|
193: void setPos(Goffset pos, int dir) override { str->getBaseStream()->setPos(pos, dir); }
|
196: Dict *getDict() override { return str->getBaseStream()->getDict(); }
|
197: Object *getDictObject() override { return str->getBaseStream()->getDictObject(); }
|
214: str = new ASCIIHexStream(str);
|
240: str = new LZWStream(str, pred, columns, colors, bits, early);
|
242: str = new RunLengthStream(str);
|
286: str = new CCITTFaxStream(str, encoding, endOfLine, byteAlign,
|
297: str = new DCTStream(str, colorXform, dict, recursion);
|
300: str = new EOFStream(str);
|
321: str = new FlateStream(str, pred, columns, colors, bits);
|
332: str = new JPXStream(str);
|
335: str = new EOFStream(str);
|
339: str = new BaseStreamStream(str);
|
345: str = new EOFStream(str);
|
351: // OutStream
|
362: // FileOutStream
|
375: void FileOutStream::close ()
|
380: Goffset FileOutStream::getPos ()
|
385: void FileOutStream::put (char c)
|
390: void FileOutStream::printf(const char *format, ...)
|
400: // BaseStream
|
412: // FilterStream
|
422: void FilterStream::close() {
|
426: void FilterStream::setPos(Goffset pos, int dir) {
|
427: error(errInternal, -1, "Internal: called setPos() on FilterStream");
|
431: // ImageStream
|
471: void ImageStream::reset() {
|
475: void ImageStream::close() {
|
479: bool ImageStream::getPixel(unsigned char *pix) {
|
494: unsigned char *ImageStream::getLine() {
|
546: void ImageStream::skipLine() {
|
551: // StreamPredictor
|
585: int StreamPredictor::lookChar() {
|
594: int StreamPredictor::getChar() {
|
603: int StreamPredictor::getChars(int nChars, unsigned char *buffer) {
|
624: bool StreamPredictor::getNextLine() {
|
749: // FileStream
|
754: BaseStream(std::move(dictA), lengthA) {
|
770: BaseStream *FileStream::copy() {
|
771: return new FileStream(file, start, limited, length, dict.copy());
|
776: return new FileStream(file, startA, limitedA, lengthA, std::move(dictA));
|
779: void FileStream::reset() {
|
787: void FileStream::close() {
|
794: bool FileStream::fillBuf() {
|
819: void FileStream::setPos(Goffset pos, int dir) {
|
834: void FileStream::moveStart(Goffset delta) {
|
841: // CachedFileStream
|
846: : BaseStream(std::move(dictA), lengthA)
|
864: BaseStream *CachedFileStream::copy() {
|
866: return new CachedFileStream(cc, start, limited, length, dict.copy());
|
873: return new CachedFileStream(cc, startA, limitedA, lengthA, std::move(dictA));
|
876: void CachedFileStream::reset()
|
886: void CachedFileStream::close()
|
894: bool CachedFileStream::fillBuf()
|
916: void CachedFileStream::setPos(Goffset pos, int dir)
|
937: void CachedFileStream::moveStart(Goffset delta)
|
945: // EmbedStream
|
950: BaseStream(std::move(dictA), lengthA) {
|
970: BaseStream *EmbedStream::copy() {
|
971: error(errInternal, -1, "Called copy() on EmbedStream");
|
977: error(errInternal, -1, "Called makeSubStream() on EmbedStream");
|
981: void EmbedStream::rewind() {
|
987: void EmbedStream::restore() {
|
991: Goffset EmbedStream::getPos() {
|
998: int EmbedStream::getChar() {
|
1022: int EmbedStream::lookChar() {
|
1036: int EmbedStream::getChars(int nChars, unsigned char *buffer) {
|
1069: void EmbedStream::setPos(Goffset pos, int dir) {
|
1070: error(errInternal, -1, "Internal: called setPos() on EmbedStream");
|
1073: Goffset EmbedStream::getStart() {
|
1074: error(errInternal, -1, "Internal: called getStart() on EmbedStream");
|
1078: void EmbedStream::moveStart(Goffset delta) {
|
1079: error(errInternal, -1, "Internal: called moveStart() on EmbedStream");
|
1083: // ASCIIHexStream
|
1087: FilterStream(strA) {
|
1096: void ASCIIHexStream::reset() {
|
1102: int ASCIIHexStream::lookChar() {
|
1157: GooString *ASCIIHexStream::getPSFilter(int psLevel, const char *indent) {
|
1170: bool ASCIIHexStream::isBinary(bool last) {
|
1179: FilterStream(strA) {
|
1256: // LZWStream
|
1261: FilterStream(strA) {
|
1263: pred = new StreamPredictor(this, predictor, columns, colors, bits);
|
1284: int LZWStream::getChar() {
|
1299: int LZWStream::lookChar() {
|
1314: void LZWStream::getRawChars(int nChars, int *buffer) {
|
1319: int LZWStream::getRawChar() {
|
1323: int LZWStream::getChars(int nChars, unsigned char *buffer) {
|
1350: void LZWStream::reset() {
|
1357: bool LZWStream::processNextCode() {
|
1424: void LZWStream::clearTable() {
|
1432: int LZWStream::getCode() {
|
1447: GooString *LZWStream::getPSFilter(int psLevel, const char *indent) {
|
1464: bool LZWStream::isBinary(bool last) {
|
1469: // RunLengthStream
|
1473: FilterStream(strA) {
|
1482: void RunLengthStream::reset() {
|
1488: int RunLengthStream::getChars(int nChars, unsigned char *buffer) {
|
1509: GooString *RunLengthStream::getPSFilter(int psLevel, const char *indent) {
|
1522: bool RunLengthStream::isBinary(bool last) {
|
1526: bool RunLengthStream::fillBuf() {
|
1553: // CCITTFaxStream
|
1559: FilterStream(strA) {
|
1601: void CCITTFaxStream::ccittReset(bool unfiltered) {
|
1615: void CCITTFaxStream::unfilteredReset() {
|
1619: void CCITTFaxStream::reset() {
|
1646: inline void CCITTFaxStream::addPixels(int a1, int blackPixels) {
|
1661: inline void CCITTFaxStream::addPixelsNeg(int a1, int blackPixels) {
|
1686: int CCITTFaxStream::lookChar() {
|
2132: short CCITTFaxStream::getTwoDimCode() {
|
2166: short CCITTFaxStream::getWhiteCode() {
|
2224: short CCITTFaxStream::getBlackCode() {
|
2300: short CCITTFaxStream::lookBits(int n) {
|
2320: GooString *CCITTFaxStream::getPSFilter(int psLevel, const char *indent) {
|
2357: bool CCITTFaxStream::isBinary(bool last) {
|
2364: // DCTStream
|
2409: FilterStream(strA) {
|
2442: void DCTStream::dctReset(bool unfiltered) {
|
2459: void DCTStream::unfilteredReset() {
|
2463: void DCTStream::reset() {
|
2558: void DCTStream::close() {
|
2569: FilterStream::close();
|
2572: int DCTStream::getChar() {
|
2613: int DCTStream::lookChar() {
|
2633: void DCTStream::restart() {
|
2645: bool DCTStream::readMCURow() {
|
2770: void DCTStream::readScan() {
|
2875: bool DCTStream::readDataUnit(DCTHuffTable *dcHuffTable,
|
2925: bool DCTStream::readProgressiveDataUnit(DCTHuffTable *dcHuffTable,
|
3051: void DCTStream::decodeImage() {
|
3193: void DCTStream::transformDataUnit(unsigned short *quantTable,
|
3351: int DCTStream::readHuffSym(DCTHuffTable *table) {
|
3380: int DCTStream::readAmp(int size) {
|
3395: int DCTStream::readBit() {
|
3419: bool DCTStream::readHeader() {
|
3497: bool DCTStream::readBaselineSOF() {
|
3537: bool DCTStream::readProgressiveSOF() {
|
3578: bool DCTStream::readScanInfo() {
|
3639: bool DCTStream::readQuantTables() {
|
3670: bool DCTStream::readHuffmanTables() {
|
3716: bool DCTStream::readRestartInterval() {
|
3728: bool DCTStream::readJFIFMarker() {
|
3758: bool DCTStream::readAdobeMarker() {
|
3790: bool DCTStream::readTrailer() {
|
3801: int DCTStream::readMarker() {
|
3815: int DCTStream::read16() {
|
3825: GooString *DCTStream::getPSFilter(int psLevel, const char *indent) {
|
3838: bool DCTStream::isBinary(bool last) {
|
3846: // FlateStream
|
3849: const int FlateStream::codeLenCodeMap[flateMaxCodeLenCodes] = {
|
3853: const FlateDecode FlateStream::lengthDecode[flateMaxLitCodes-257] = {
|
3887: const FlateDecode FlateStream::distDecode[flateMaxDistCodes] = {
|
4435: FlateHuffmanTab FlateStream::fixedLitCodeTab = {
|
4474: FlateHuffmanTab FlateStream::fixedDistCodeTab = {
|
4480: FilterStream(strA) {
|
4482: pred = new StreamPredictor(this, predictor, columns, colors, bits);
|
4508: void FlateStream::flateReset(bool unfiltered) {
|
4523: void FlateStream::unfilteredReset() {
|
4527: void FlateStream::reset() {
|
4555: int FlateStream::getChar() {
|
4562: int FlateStream::getChars(int nChars, unsigned char *buffer) {
|
4575: int FlateStream::lookChar() {
|
4590: void FlateStream::getRawChars(int nChars, int *buffer) {
|
4595: int FlateStream::getRawChar() {
|
4599: GooString *FlateStream::getPSFilter(int psLevel, const char *indent) {
|
4612: bool FlateStream::isBinary(bool last) {
|
4616: void FlateStream::readSome() {
|
4681: bool FlateStream::startBlock() {
|
4748: void FlateStream::loadFixedCodes() {
|
4755: bool FlateStream::readDynamicCodes() {
|
4857: FlateCode *FlateStream::compHuffmanCodes(const int *lengths, int n, int *maxLen) {
|
4907: int FlateStream::getHuffmanCodeWord(FlateHuffmanTab *tab) {
|
4927: int FlateStream::getCodeWord(int bits) {
|
4944: // EOFStream
|
4948: FilterStream(strA) {
|
4956: // BufStream
|
4969: void BufStream::reset() {
|
4978: int BufStream::getChar() {
|
4989: int BufStream::lookChar() {
|
4993: int BufStream::lookChar(int idx) {
|
4997: bool BufStream::isBinary(bool last) {
|
5006: FilterStream(strA) {
|
5043: FilterStream(strA) {
|
5090: FilterStream(strA) {
|
5182: FilterStream(strA) {
|
5287: FilterStream(strA)
|
5432: FilterStream(strA) {
|
5475: FilterStream(strA) {
|
802: if (limited && bufPos + fileStreamBufSize > start + length) {
|
805: n = fileStreamBufSize;
|
903: if (limited && bufPos + cachedStreamBufSize > start + length) {
|
906: n = cachedStreamBufSize - (bufPos % cachedStreamBufSize);
|
github.com/apache/incubator-retired-s4:subprojects/s4-core/src/main/java/org/apache/s4/core/Stream.java: [ piper, ] |
---|
42: public class Stream<T extends Event> implements Runnable, Streamable {
|
67: public Stream(App app) {
|
35: * {@link Stream} and {@link ProcessingElement} objects represent the links and nodes in the application graph. A st...(4 bytes skipped)...
|
44: private static final Logger logger = LoggerFactory.getLogger(Stream.class);
|
97: public Stream<T> setName(String name) {
|
109: public Stream<T> setKey(KeyFinder<T> keyFinder) {
|
118: Stream<T> setEventType(Class<T> type) {
|
130: public Stream<T> setKey(String keyName) {
|
148: public Stream<T> setPE(ProcessingElement pe) {
|
161: public Stream<T> setPEs(ProcessingElement[] pes) {
|
322: public Stream<T> register() {
|
87: this.receiver.addStream(this);
|
149: app.addStream(this);
|
315: receiver.removeStream(this);
|
323: app.addStream(this);
|
174: event.setStreamId(getName());
|
192: queue.put(new EventMessage(String.valueOf(event.getAppId()), event.getStreamName(), app
|
204: queue.put(new EventMessage(String.valueOf(event.getAppId()), event.getStreamName(), app.getSerDeser()
|
github.com/apache/maven-scm:maven-scm-providers/maven-scm-provider-accurev/src/main/java/org/apache/maven/scm/provider/accurev/Stream.java: [ master, ] |
---|
27: public class Stream
|
44: public Stream( String name, long id, String basis, long basisId, String depot, Date startDate, String streamType ...(1 bytes skipped)...
|
182: public String getStreamType()
|
85: Stream other = (Stream) obj;
|
github.com/sparkfun/Arduino_Boards:sparkfun/samd/cores/arduino/Stream.h: [ master, ] |
---|
49: class Stream : public Print
|
63: Stream() {_timeout=1000;}
|
23: #define Stream_h
|
2: Stream.h - base class for character-based streams.
|
22: #ifndef Stream_h
|
114: // Stream and used parseFloat/Int with a custom ignore character. To keep
|
github.com/sparkfun/Arduino_Boards:sparkfun/samd/cores/arduino51/Stream.h: [ master, ] Duplicate result |
---|
github.com/sparkfun/Arduino_Boards:sparkfun/samd/cores/LilyMini/Stream.h: [ master, ] |
---|
49: class Stream : public Print
|
64: Stream() {_timeout=1000;}
|
23: #define Stream_h
|
2: Stream.h - base class for character-based streams.
|
22: #ifndef Stream_h
|
115: // Stream and used parseFloat/Int with a custom ignore character. To keep
|
android.googlesource.com/platform/frameworks/ex:framesequence/jni/Stream.h: [ master, ] |
---|
24: class Stream {
|
44: class MemoryStream : public Stream {
|
46: MemoryStream(void* buffer, size_t size, jobject buf) :
|
63: class FileStream : public Stream {
|
65: FileStream(FILE* fd) : mFd(fd) {}
|
74: class JavaInputStream : public Stream {
|
76: JavaInputStream(JNIEnv* env, jobject inputStream, jbyteArray byteArray) :
|
87: const jobject mInputStream;
|
26: Stream();
|
27: virtual ~Stream();
|
78: mInputStream(inputStream),
|
92: jint JavaStream_OnLoad(JNIEnv* env);
|
android.googlesource.com/platform/frameworks/ex:framesequence/jni/Stream.cpp: [ master, ] |
---|
32: Stream::Stream()
|
38: Stream::~Stream() {
|
143: jint JavaStream_OnLoad(JNIEnv* env) {
|
30: } gInputStreamClassInfo;
|
17: #define LOG_TAG "Stream"
|
19: #include "Stream.h"
|
42: size_t Stream::peek(void* buffer, size_t size) {
|
60: size_t Stream::read(void* buffer, size_t size) {
|
82: uint8_t* Stream::getRawBufferAddr() {
|
86: jobject Stream::getRawBuffer() {
|
90: int Stream::getRawBufferSize() {
|
94: uint8_t* MemoryStream::getRawBufferAddr() {
|
98: jobject MemoryStream::getRawBuffer() {
|
102: int MemoryStream::getRawBufferSize() {
|
110: size_t MemoryStream::doRead(void* buffer, size_t size) {
|
118: size_t FileStream::doRead(void* buffer, size_t size) {
|
122: size_t JavaInputStream::doRead(void* dstBuffer, size_t size) {
|
128: jint bytesRead = mEnv->CallIntMethod(mInputStream,
|
146: jclass inputStreamClazz = env->FindClass("java/io/InputStream");
|
129: gInputStreamClassInfo.read, mByteArray, 0, requested);
|
147: if (!inputStreamClazz) {
|
150: gInputStreamClassInfo.read = env->GetMethodID(inputStreamClazz, "read", "([BII)I");
|
151: gInputStreamClassInfo.reset = env->GetMethodID(inputStreamClazz, "reset", "()V");
|
152: if (!gInputStreamClassInfo.read || !gInputStreamClassInfo.reset) {
|
github.com/sparkfun/BadgerStick:badgerstick/avr/cores/arduino/Stream.h: [ master, ] |
---|
38: class Stream : public Print
|
53: Stream() {_timeout=1000;}
|
23: #define Stream_h
|
2: Stream.h - base class for character-based streams.
|
22: #ifndef Stream_h
|
github.com/googleads/googleads-ima-tvos-dai:ObjectiveC/AdvancedExample/app/Stream.h: [ master, ] |
---|
22: @interface Stream : NSObject
|
20: /// the Stream class defines a standard for storing information about a video stream that will be
|
github.com/google/gulava:java/gulava/Stream.java: [ master, ] |
---|
31: public interface Stream {
|
35: * which the solutions are returned depends on the implementations of {@code Stream} used.
|
37: Stream mplus(Stream s2);
|
44: Stream bind(Goal goal);
|
55: Stream rest();
|
github.com/sparkfun/PSoC_Arduino_Support:Hardware/SparkFun/psoc/cores/arduino/Stream.h: [ master, ] |
---|
38: class Stream : public Print
|
54: Stream() {_timeout=1000;}
|
23: #define Stream_h
|
48: ~Stream(){}
|
2: Stream.h - base class for character-based streams.
|
22: #ifndef Stream_h
|
github.com/apache/incubator-optiq-linq4j:src/main/java/net/hydromatic/lambda/streams/Stream.java: [ master, ] |
---|
27: public interface Stream<T> extends SequentialStreamOps<T>, Iterator<T> {
|
23: * Stream.
|
25: * <p>Based on {@code java.util.streams.Stream}.</p>
|
35: // End Stream.java
|
github.com/apache/accumulo-testing:src/main/java/org/apache/accumulo/testing/stress/Stream.java: [ master, ] |
---|
26: public abstract class Stream<T> implements Iterator<T> {
|
github.com/sparkfun/MaKeyMaKey:firmware/Arduino/hardware/MaKeyMaKey/cores/arduino/Stream.h: [ master, ] |
---|
38: class Stream : public Print
|
53: Stream() {_timeout=1000;}
|
23: #define Stream_h
|
2: Stream.h - base class for character-based streams.
|
22: #ifndef Stream_h
|
android.googlesource.com/platform/external/arduino:hardware/arduino/cores/arduino/Stream.h: [ master, ] |
---|
26: class Stream : public Print
|
21: #define Stream_h
|
2: Stream.h - base class for character-based streams.
|
20: #ifndef Stream_h
|
github.com/googleads/googleads-ima-tvos-dai:ObjectiveC/AdvancedExample/app/Stream.m: [ master, ] |
---|
21: @implementation Stream
|
17: #import "Stream.h"
|
19: /// The Stream class defines a standard for storing information about a video stream that will be
|
github.com/apache/sling-samples:slingshot/src/main/java/org/apache/sling/sample/slingshot/model/Stream.java: [ master, ] |
---|
23: public class Stream {
|
32: public Stream(final Resource resource) {
|
26: public static final String RESOURCETYPE = "slingshot/Stream";
|
30: private volatile StreamInfo info;
|
36: public StreamInfo getInfo() {
|
38: info = new StreamInfo(this.resource == null ? null : this.resource.getChild("info"));
|
github.com/tensorflow/tensorflow:tensorflow/stream_executor/stream.cc: [ master, ] |
---|
250: Stream::Stream(StreamExecutor *parent)
|
259: Stream::Stream(StreamExecutor *parent,
|
269: Stream::~Stream() {
|
1290: Stream *Stream::GetOrCreateSubStream() {
|
1342: void Stream::ReturnSubStream(Stream *sub_stream) {
|
5001: std::string Stream::DebugStreamPointers() const {
|
208: // there are on Stream and how many parameters they each have.
|
209: std::string CallStr(const char *function_name, Stream *stream,
|
216: " Called Stream::", function_name, "(");
|
286: port::Status Stream::RefreshStatus() {
|
297: Stream &Stream::Init() {
|
316: Stream &Stream::InitTimer(Timer *timer) {
|
323: Stream &Stream::InitWithTimer(Timer *timer) {
|
329: Stream &Stream::ThenRecordEvent(Event *event) {
|
342: Stream &Stream::ThenBatchNormalizationForward(
|
370: Stream &Stream::ThenBatchNormalizationBackward(
|
393: Stream &Stream::ThenBatchNormalizationForward(
|
421: Stream &Stream::ThenBatchNormalizationBackward(
|
446: port::Status Stream::FusedConvolveWithAlgorithm(
|
477: port::Status Stream::FusedConvolveWithAlgorithm(
|
508: port::Status Stream::FusedConvolveWithAlgorithm(
|
540: port::Status Stream::FusedConvolveWithAlgorithm(
|
571: port::Status Stream::FusedConvolveWithAlgorithm(
|
602: Stream &Stream::ThenConvolve(
|
621: Stream &Stream::ThenConvolveQuantized(
|
648: Stream &Stream::ThenConvolveQuantized(
|
675: Stream &Stream::ThenSeparableConvolve(
|
701: Stream &Stream::ThenConvolveBackwardBiasImpl(
|
719: Stream &Stream::ThenConvolveBackwardBias(
|
728: Stream &Stream::ThenConvolveBackwardBias(
|
737: Stream &Stream::ThenConvolveBackwardBias(
|
746: Stream &Stream::ThenMatMul(const DeviceMemory<float> &input_data,
|
763: Stream &Stream::ThenMatMulQuantized(
|
783: Stream &Stream::ThenMatMulQuantized(
|
803: Stream &Stream::ThenBiasAdd(const DeviceMemory<float> &input_data,
|
819: Stream &Stream::ThenPoolForward(
|
841: Stream &Stream::ThenPoolForward(
|
861: Stream &Stream::ThenPoolForward(
|
882: Stream &Stream::ThenPoolForward(
|
902: Stream &Stream::ThenPoolBackward(
|
929: Stream &Stream::ThenPoolBackward(
|
954: Stream &Stream::ThenPoolBackward(
|
979: Stream &Stream::ThenNormalizeWithDimensions(
|
995: Stream &Stream::ThenNormalizeBackwardWithDimensions(
|
1017: Stream &Stream::ThenActivate(dnn::ActivationMode activation_mode,
|
1025: Stream &Stream::ThenActivateWithOptions(dnn::ActivationMode activation_mode,
|
1042: Stream &Stream::ThenDepthConcatenate(
|
1070: Stream &Stream::ThenSpaceConcatenate(
|
1115: Stream &Stream::ThenReshape(const dnn::BatchDescriptor &input_dimensions,
|
1131: Stream &Stream::ThenDepthToSpace(
|
1150: Stream &Stream::ThenSpaceToDepth(
|
1169: Stream &Stream::ThenElementwiseOperate(
|
1188: Stream &Stream::ThenElementwiseOperateScaledQuantized(
|
1209: Stream &Stream::ThenXYPad(const dnn::BatchDescriptor &dimensions,
|
1226: Stream &Stream::ThenXYSlice(const dnn::BatchDescriptor &dimensions,
|
1244: Stream &Stream::ThenXYBroadcast(const dnn::BatchDescriptor &dimensions,
|
1260: Stream &Stream::ThenMemcpyD2HQuantized(
|
1275: Stream &Stream::ThenMemcpyH2DQuantized(
|
1291: // Do not destroy bad streams when holding mu_ because ~Stream() may
|
1293: std::vector<std::unique_ptr<Stream>> bad_streams;
|
1300: std::pair<std::unique_ptr<Stream>, bool> &pair = sub_streams_[index];
|
1303: Stream *sub_stream = pair.first.get();
|
1329: sub_streams_.emplace_back(std::unique_ptr<Stream>{new Stream{parent_}},
|
1331: Stream *sub_stream = sub_streams_.back().first.get();
|
1343: // Do not destroy bad streams when holding mu_ because ~Stream() may
|
1345: std::unique_ptr<Stream> bad_stream;
|
1351: std::pair<std::unique_ptr<Stream>, bool> &pair = sub_streams_[index];
|
1382: Stream &Stream::ThenStartTimer(Timer *t) {
|
1389: Stream &Stream::ThenStopTimer(Timer *t) {
|
1396: Stream &Stream::ThenWaitFor(Stream *other) {
|
1410: Stream &Stream::ThenWaitFor(Event *event) {
|
1432: // arguments except the first one of Stream* type.
|
1433: Stream &operator()(Stream *stream,
|
1434: bool (blas::BlasSupport::*blas_func)(Stream *, Args...),
|
1441: Stream &Run(Stream *stream,
|
1442: bool (blas::BlasSupport::*blas_func)(Stream *, Args...),
|
1447: Stream &ThenBlasImpl<Args...>::Run(
|
1448: Stream *stream, bool (blas::BlasSupport::*blas_func)(Stream *, Args...),
|
1467: Stream &Stream::ThenBlasAsum(uint64 elem_count, const DeviceMemory<float> &x,
|
1477: Stream &Stream::ThenBlasAsum(uint64 elem_count, const DeviceMemory<double> &x,
|
1488: Stream &Stream::ThenBlasAsum(uint64 elem_count,
|
1500: Stream &Stream::ThenBlasAsum(uint64 elem_count,
|
1512: Stream &Stream::ThenBlasAxpy(uint64 elem_count, float alpha,
|
1525: Stream &Stream::ThenBlasAxpy(uint64 elem_count, double alpha,
|
1538: Stream &Stream::ThenBlasAxpy(uint64 elem_count, std::complex<float> alpha,
|
1553: Stream &Stream::ThenBlasAxpy(uint64 elem_count, std::complex<double> alpha,
|
1568: Stream &Stream::ThenBlasCopy(uint64 elem_count, const DeviceMemory<float> &x,
|
1579: Stream &Stream::ThenBlasCopy(uint64 elem_count, const DeviceMemory<double> &x,
|
1590: Stream &Stream::ThenBlasCopy(uint64 elem_count,
|
1603: Stream &Stream::ThenBlasCopy(uint64 elem_count,
|
1616: Stream &Stream::ThenBlasDot(uint64 elem_count, const DeviceMemory<float> &x,
|
1629: Stream &Stream::ThenBlasDot(uint64 elem_count, const DeviceMemory<double> &x,
|
1642: Stream &Stream::ThenBlasDotc(uint64 elem_count,
|
1659: Stream &Stream::ThenBlasDotc(uint64 elem_count,
|
1676: Stream &Stream::ThenBlasDotu(uint64 elem_count,
|
1693: Stream &Stream::ThenBlasDotu(uint64 elem_count,
|
1710: Stream &Stream::ThenBlasNrm2(uint64 elem_count, const DeviceMemory<float> &x,
|
1720: Stream &Stream::ThenBlasNrm2(uint64 elem_count, const DeviceMemory<double> &x,
|
1731: Stream &Stream::ThenBlasNrm2(uint64 elem_count,
|
1743: Stream &Stream::ThenBlasNrm2(uint64 elem_count,
|
1755: Stream &Stream::ThenBlasRot(uint64 elem_count, DeviceMemory<float> *x, int incx,
|
1768: Stream &Stream::ThenBlasRot(uint64 elem_count, DeviceMemory<double> *x,
|
1781: Stream &Stream::ThenBlasRot(uint64 elem_count,
|
1795: Stream &Stream::ThenBlasRot(uint64 elem_count,
|
1809: Stream &Stream::ThenBlasRotg(DeviceMemory<float> *a, DeviceMemory<float> *b,
|
1819: Stream &Stream::ThenBlasRotg(DeviceMemory<double> *a, DeviceMemory<double> *b,
|
1829: Stream &Stream::ThenBlasRotg(DeviceMemory<std::complex<float>> *a,
|
1842: Stream &Stream::ThenBlasRotg(DeviceMemory<std::complex<double>> *a,
|
1855: Stream &Stream::ThenBlasRotm(uint64 elem_count, DeviceMemory<float> *x,
|
1868: Stream &Stream::ThenBlasRotm(uint64 elem_count, DeviceMemory<double> *x,
|
1881: Stream &Stream::ThenBlasRotmg(DeviceMemory<float> *d1, DeviceMemory<float> *d2,
|
1894: Stream &Stream::ThenBlasRotmg(DeviceMemory<double> *d1,
|
1908: Stream &Stream::ThenBlasScal(uint64 elem_count, float alpha,
|
1916: Stream &Stream::ThenBlasScal(uint64 elem_count, double alpha,
|
1924: Stream &Stream::ThenBlasScal(uint64 elem_count, float alpha,
|
1932: Stream &Stream::ThenBlasScal(uint64 elem_count, double alpha,
|
1940: Stream &Stream::ThenBlasScal(uint64 elem_count, std::complex<float> alpha,
|
1950: Stream &Stream::ThenBlasScal(uint64 elem_count, std::complex<double> alpha,
|
1960: Stream &Stream::ThenBlasSwap(uint64 elem_count, DeviceMemory<float> *x,
|
1970: Stream &Stream::ThenBlasSwap(uint64 elem_count, DeviceMemory<double> *x,
|
1980: Stream &Stream::ThenBlasSwap(uint64 elem_count,
|
1992: Stream &Stream::ThenBlasSwap(uint64 elem_count,
|
2004: Stream &Stream::ThenBlasIamax(uint64 elem_count, const DeviceMemory<float> &x,
|
2014: Stream &Stream::ThenBlasIamax(uint64 elem_count, const DeviceMemory<double> &x,
|
2024: Stream &Stream::ThenBlasIamax(uint64 elem_count,
|
2036: Stream &Stream::ThenBlasIamax(uint64 elem_count,
|
2048: Stream &Stream::ThenBlasIamin(uint64 elem_count, const DeviceMemory<float> &x,
|
2058: Stream &Stream::ThenBlasIamin(uint64 elem_count, const DeviceMemory<double> &x,
|
2068: Stream &Stream::ThenBlasIamin(uint64 elem_count,
|
2080: Stream &Stream::ThenBlasIamin(uint64 elem_count,
|
2092: Stream &Stream::ThenBlasGbmv(blas::Transpose trans, uint64 m, uint64 n,
|
2109: Stream &Stream::ThenBlasGbmv(blas::Transpose trans, uint64 m, uint64 n,
|
2126: Stream &Stream::ThenBlasGbmv(blas::Transpose trans, uint64 m, uint64 n,
|
2146: Stream &Stream::ThenBlasGbmv(blas::Transpose trans, uint64 m, uint64 n,
|
2166: Stream &Stream::ThenBlasGemv(blas::Transpose trans, uint64 m, uint64 n,
|
2182: Stream &Stream::ThenBlasGemv(blas::Transpose trans, uint64 m, uint64 n,
|
2198: Stream &Stream::ThenBlasGemv(blas::Transpose trans, uint64 m, uint64 n,
|
2218: Stream &Stream::ThenBlasGemv(blas::Transpose trans, uint64 m, uint64 n,
|
2238: Stream &Stream::ThenBlasGer(uint64 m, uint64 n, float alpha,
|
2252: Stream &Stream::ThenBlasGer(uint64 m, uint64 n, double alpha,
|
2266: Stream &Stream::ThenBlasGerc(uint64 m, uint64 n, std::complex<float> alpha,
|
2284: Stream &Stream::ThenBlasGerc(uint64 m, uint64 n, std::complex<double> alpha,
|
2302: Stream &Stream::ThenBlasGeru(uint64 m, uint64 n, std::complex<float> alpha,
|
2320: Stream &Stream::ThenBlasGeru(uint64 m, uint64 n, std::complex<double> alpha,
|
2338: Stream &Stream::ThenBlasHbmv(blas::UpperLower uplo, uint64 n, uint64 k,
|
2357: Stream &Stream::ThenBlasHbmv(blas::UpperLower uplo, uint64 n, uint64 k,
|
2376: Stream &Stream::ThenBlasHemv(blas::UpperLower uplo, uint64 n,
|
2395: Stream &Stream::ThenBlasHemv(blas::UpperLower uplo, uint64 n,
|
2414: Stream &Stream::ThenBlasHer(blas::UpperLower uplo, uint64 n, float alpha,
|
2429: Stream &Stream::ThenBlasHer(blas::UpperLower uplo, uint64 n, double alpha,
|
2444: Stream &Stream::ThenBlasHer2(blas::UpperLower uplo, uint64 n,
|
2463: Stream &Stream::ThenBlasHer2(blas::UpperLower uplo, uint64 n,
|
2482: Stream &Stream::ThenBlasHpmv(blas::UpperLower uplo, uint64 n,
|
2500: Stream &Stream::ThenBlasHpmv(blas::UpperLower uplo, uint64 n,
|
2518: Stream &Stream::ThenBlasHpr(blas::UpperLower uplo, uint64 n, float alpha,
|
2531: Stream &Stream::ThenBlasHpr(blas::UpperLower uplo, uint64 n, double alpha,
|
2544: Stream &Stream::ThenBlasHpr2(blas::UpperLower uplo, uint64 n,
|
2562: Stream &Stream::ThenBlasHpr2(blas::UpperLower uplo, uint64 n,
|
2580: Stream &Stream::ThenBlasSbmv(blas::UpperLower uplo, uint64 n, uint64 k,
|
2595: Stream &Stream::ThenBlasSbmv(blas::UpperLower uplo, uint64 n, uint64 k,
|
2610: Stream &Stream::ThenBlasSpmv(blas::UpperLower uplo, uint64 n, float alpha,
|
2625: Stream &Stream::ThenBlasSpmv(blas::UpperLower uplo, uint64 n, double alpha,
|
2640: Stream &Stream::ThenBlasSpr(blas::UpperLower uplo, uint64 n, float alpha,
|
2652: Stream &Stream::ThenBlasSpr(blas::UpperLower uplo, uint64 n, double alpha,
|
2664: Stream &Stream::ThenBlasSpr2(blas::UpperLower uplo, uint64 n, float alpha,
|
2678: Stream &Stream::ThenBlasSpr2(blas::UpperLower uplo, uint64 n, double alpha,
|
2692: Stream &Stream::ThenBlasSymv(blas::UpperLower uplo, uint64 n, float alpha,
|
2707: Stream &Stream::ThenBlasSymv(blas::UpperLower uplo, uint64 n, double alpha,
|
2722: Stream &Stream::ThenBlasSyr(blas::UpperLower uplo, uint64 n, float alpha,
|
2735: Stream &Stream::ThenBlasSyr(blas::UpperLower uplo, uint64 n, double alpha,
|
2748: Stream &Stream::ThenBlasSyr2(blas::UpperLower uplo, uint64 n, float alpha,
|
2763: Stream &Stream::ThenBlasSyr2(blas::UpperLower uplo, uint64 n, double alpha,
|
2778: Stream &Stream::ThenBlasTbmv(blas::UpperLower uplo, blas::Transpose trans,
|
2793: Stream &Stream::ThenBlasTbmv(blas::UpperLower uplo, blas::Transpose trans,
|
2808: Stream &Stream::ThenBlasTbmv(blas::UpperLower uplo, blas::Transpose trans,
|
2824: Stream &Stream::ThenBlasTbmv(blas::UpperLower uplo, blas::Transpose trans,
|
2840: Stream &Stream::ThenBlasTbsv(blas::UpperLower uplo, blas::Transpose trans,
|
2855: Stream &Stream::ThenBlasTbsv(blas::UpperLower uplo, blas::Transpose trans,
|
2870: Stream &Stream::ThenBlasTbsv(blas::UpperLower uplo, blas::Transpose trans,
|
2886: Stream &Stream::ThenBlasTbsv(blas::UpperLower uplo, blas::Transpose trans,
|
2902: Stream &Stream::ThenBlasTpmv(blas::UpperLower uplo, blas::Transpose trans,
|
2916: Stream &Stream::ThenBlasTpmv(blas::UpperLower uplo, blas::Transpose trans,
|
2930: Stream &Stream::ThenBlasTpmv(blas::UpperLower uplo, blas::Transpose trans,
|
2945: Stream &Stream::ThenBlasTpmv(blas::UpperLower uplo, blas::Transpose trans,
|
2960: Stream &Stream::ThenBlasTpsv(blas::UpperLower uplo, blas::Transpose trans,
|
2974: Stream &Stream::ThenBlasTpsv(blas::UpperLower uplo, blas::Transpose trans,
|
2988: Stream &Stream::ThenBlasTpsv(blas::UpperLower uplo, blas::Transpose trans,
|
3003: Stream &Stream::ThenBlasTpsv(blas::UpperLower uplo, blas::Transpose trans,
|
3018: Stream &Stream::ThenBlasTrmv(blas::UpperLower uplo, blas::Transpose trans,
|
3032: Stream &Stream::ThenBlasTrmv(blas::UpperLower uplo, blas::Transpose trans,
|
3046: Stream &Stream::ThenBlasTrmv(blas::UpperLower uplo, blas::Transpose trans,
|
3062: Stream &Stream::ThenBlasTrmv(blas::UpperLower uplo, blas::Transpose trans,
|
3078: Stream &Stream::ThenBlasTrsv(blas::UpperLower uplo, blas::Transpose trans,
|
3092: Stream &Stream::ThenBlasTrsv(blas::UpperLower uplo, blas::Transpose trans,
|
3106: Stream &Stream::ThenBlasTrsv(blas::UpperLower uplo, blas::Transpose trans,
|
3122: Stream &Stream::ThenBlasTrsv(blas::UpperLower uplo, blas::Transpose trans,
|
3138: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3157: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3174: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3191: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3212: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3240: Stream &operator()(Stream *stream,
|
3242: Stream *, Args..., blas::ProfileResult *),
|
3251: Stream &Stream::ThenBlasGemvWithProfiling(
|
3268: Stream &Stream::ThenBlasGemvWithProfiling(
|
3286: Stream &Stream::ThenBlasGemvWithProfiling(
|
3306: Stream &Stream::ThenBlasGemvWithProfiling(
|
3326: Stream &Stream::ThenBlasGemmWithProfiling(
|
3346: Stream &Stream::ThenBlasGemmWithProfiling(
|
3365: Stream &Stream::ThenBlasGemmWithProfiling(
|
3385: Stream &Stream::ThenBlasGemmWithProfiling(
|
3407: Stream &Stream::ThenBlasGemmWithProfiling(
|
3429: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3454: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3477: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3500: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3524: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3552: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3580: Stream &Stream::ThenBlasHemm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
3600: Stream &Stream::ThenBlasHemm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
3620: Stream &Stream::ThenBlasHerk(blas::UpperLower uplo, blas::Transpose trans,
|
3636: Stream &Stream::ThenBlasHerk(blas::UpperLower uplo, blas::Transpose trans,
|
3652: Stream &Stream::ThenBlasHer2k(blas::UpperLower uplo, blas::Transpose trans,
|
3672: Stream &Stream::ThenBlasHer2k(blas::UpperLower uplo, blas::Transpose trans,
|
3692: Stream &Stream::ThenBlasSymm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
3709: Stream &Stream::ThenBlasSymm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
3726: Stream &Stream::ThenBlasSymm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
3746: Stream &Stream::ThenBlasSymm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
3766: Stream &Stream::ThenBlasSyrk(blas::UpperLower uplo, blas::Transpose trans,
|
3781: Stream &Stream::ThenBlasSyrk(blas::UpperLower uplo, blas::Transpose trans,
|
3796: Stream &Stream::ThenBlasSyrk(blas::UpperLower uplo, blas::Transpose trans,
|
3813: Stream &Stream::ThenBlasSyrk(blas::UpperLower uplo, blas::Transpose trans,
|
3830: Stream &Stream::ThenBlasSyr2k(blas::UpperLower uplo, blas::Transpose trans,
|
3847: Stream &Stream::ThenBlasSyr2k(blas::UpperLower uplo, blas::Transpose trans,
|
3864: Stream &Stream::ThenBlasSyr2k(blas::UpperLower uplo, blas::Transpose trans,
|
3884: Stream &Stream::ThenBlasSyr2k(blas::UpperLower uplo, blas::Transpose trans,
|
3904: Stream &Stream::ThenBlasTrmm(blas::Side side, blas::UpperLower uplo,
|
3920: Stream &Stream::ThenBlasTrmm(blas::Side side, blas::UpperLower uplo,
|
3936: Stream &Stream::ThenBlasTrmm(blas::Side side, blas::UpperLower uplo,
|
3954: Stream &Stream::ThenBlasTrmm(blas::Side side, blas::UpperLower uplo,
|
3972: Stream &Stream::ThenBlasTrsm(blas::Side side, blas::UpperLower uplo,
|
3988: Stream &Stream::ThenBlasTrsm(blas::Side side, blas::UpperLower uplo,
|
4004: Stream &Stream::ThenBlasTrsm(blas::Side side, blas::UpperLower uplo,
|
4022: Stream &Stream::ThenBlasTrsm(blas::Side side, blas::UpperLower uplo,
|
4040: Stream &Stream::ThenBlasGemmBatched(
|
4052: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4074: Stream &Stream::ThenBlasGemmBatched(
|
4085: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4106: Stream &Stream::ThenBlasGemmBatched(
|
4117: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4138: Stream &Stream::ThenBlasGemmBatched(
|
4151: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4177: Stream &Stream::ThenBlasGemmBatched(
|
4190: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4216: Stream &Stream::ThenBlasGemmStridedBatched(
|
4237: Stream &Stream::ThenBlasGemmStridedBatched(
|
4258: Stream &Stream::ThenBlasGemmStridedBatched(
|
4279: Stream &Stream::ThenBlasGemmStridedBatched(
|
4302: Stream &Stream::ThenBlasGemmStridedBatched(
|
4326: Stream &Stream::ThenBlasLtMatmulImpl(
|
4349: template Stream &Stream::ThenBlasLtMatmulImpl<int8, int32>(
|
4356: template Stream &Stream::ThenBlasLtMatmulImpl<Eigen::half, Eigen::half>(
|
4363: template Stream &Stream::ThenBlasLtMatmulImpl<float, float>(
|
4370: template Stream &Stream::ThenBlasLtMatmulImpl<double, double>(
|
4377: template Stream &
|
4378: Stream::ThenBlasLtMatmulImpl<std::complex<float>, std::complex<float>>(
|
4388: template Stream &
|
4389: Stream::ThenBlasLtMatmulImpl<std::complex<double>, std::complex<double>>(
|
4399: Stream &Stream::ThenSetRngSeed(const uint8 *seed, uint64 seed_bytes) {
|
4411: Stream &Stream::ThenPopulateRandUniform(DeviceMemory<float> *values) {
|
4425: Stream &Stream::ThenPopulateRandGaussian(float mean, float sd,
|
4440: Stream &Stream::ThenPopulateRandGaussian(double mean, double sd,
|
4455: Stream &Stream::ThenPopulateRandUniform(DeviceMemory<double> *values) {
|
4469: Stream &Stream::ThenPopulateRandUniform(
|
4484: Stream &Stream::ThenPopulateRandUniform(
|
4499: Stream &Stream::ThenMemcpy(void *host_dst, const DeviceMemoryBase &gpu_src,
|
4507: Stream &Stream::ThenMemcpy(DeviceMemoryBase *gpu_dst, const void *host_src,
|
4515: Stream &Stream::ThenMemcpy(DeviceMemoryBase *gpu_dst,
|
4523: Stream &Stream::ThenMemZero(DeviceMemoryBase *location, uint64 size) {
|
4530: Stream &Stream::ThenMemset32(DeviceMemoryBase *location, uint32 pattern,
|
4538: Stream &Stream::ThenRnnForward(
|
4572: Stream &Stream::ThenRnnForward(
|
4605: Stream &Stream::ThenRnnForward(
|
4639: Stream &Stream::ThenRnnBackward(
|
4684: Stream &Stream::ThenRnnBackward(
|
4728: Stream &Stream::ThenRnnBackward(
|
4773: Stream &Stream::ThenCtcLoss(const dnn::RnnStateTensorDescriptor &probs_desc,
|
4806: Stream &Stream::ThenTransformTensor(const dnn::BatchDescriptor &input_desc,
|
4825: Stream &Stream::ThenDoHostCallback(std::function<void()> callback) {
|
4836: Stream &Stream::ThenDoHostCallbackWithStatus(
|
4848: Stream &Stream::ThenRunAfterNextBlockHostUntilDone(
|
4862: Stream &Stream::ThenFft(fft::Plan *plan,
|
4878: Stream &Stream::ThenFft(fft::Plan *plan,
|
4894: Stream &Stream::ThenFft(fft::Plan *plan, const DeviceMemory<float> &input,
|
4909: Stream &Stream::ThenFft(fft::Plan *plan, const DeviceMemory<double> &input,
|
4924: Stream &Stream::ThenFft(fft::Plan *plan,
|
4940: Stream &Stream::ThenFft(fft::Plan *plan,
|
4958: Stream &Stream::ThenEnqueueOnBackgroundThread(
|
4970: port::Status Stream::BlockHostUntilDone() {
|
4990: void Stream::RunAfterBlockHostUntilDoneCallbacks() {
|
5007: void Stream::CheckStatus(port::Status status) {
|
260: internal::StreamInterface *implementation)
|
282: parent_->DeallocateStream(this);
|
305: if (parent_->AllocateStream(this)) {
|
642: LOG(WARNING) << "attempting to perform DNN operation using StreamExecutor "
|
669: LOG(WARNING) << "attempting to perform DNN operation using StreamExecutor "
|
835: LOG(WARNING) << "attempting to perform DNN operation using StreamExecutor "
|
923: LOG(WARNING) << "attempting to perform DNN operation using StreamExecutor "
|
1311: // The stream is reusable and not ok. Streams have a monotonic state
|
1362: // The returned stream is not ok. Streams have a monotonic state
|
1456: << "attempting to perform BLAS operation using StreamExecutor "
|
4419: << " attempting to perform RNG operation using StreamExecutor"
|
4434: << " attempting to perform RNG operation using StreamExecutor"
|
4449: << " attempting to perform RNG operation using StreamExecutor"
|
4463: << " attempting to perform RNG operation using StreamExecutor"
|
4478: << " attempting to perform RNG operation using StreamExecutor"
|
4493: << " attempting to perform RNG operation using StreamExecutor"
|
4872: << " attempting to perform FFT operation using StreamExecutor"
|
4888: << " attempting to perform FFT operation using StreamExecutor"
|
4903: << " attempting to perform FFT operation using StreamExecutor"
|
4918: << " attempting to perform FFT operation using StreamExecutor"
|
4934: << " attempting to perform FFT operation using StreamExecutor"
|
4950: << " attempting to perform FFT operation using StreamExecutor"
|
4959: std::function<void(StreamExecutor *)> task) {
|
4962: StreamExecutor *stream_executor = this->parent_;
|
215: std::string str = absl::StrCat(stream->DebugStreamPointers(),
|
252: implementation_(parent->implementation()->GetStreamImplementation()),
|
1305: VLOG(1) << DebugStreamPointers() << " reusing sub_stream "
|
1306: << sub_stream->DebugStreamPointers();
|
1320: VLOG(1) << DebugStreamPointers() << " dropped !ok sub_stream "
|
1321: << sub_stream->DebugStreamPointers();
|
1336: VLOG(1) << DebugStreamPointers() << " created new sub_stream "
|
1337: << sub_stream->DebugStreamPointers();
|
1358: VLOG(1) << DebugStreamPointers() << " returned ok sub_stream "
|
1359: << sub_stream->DebugStreamPointers();
|
1365: VLOG(1) << DebugStreamPointers() << " returned !ok sub_stream "
|
1366: << sub_stream->DebugStreamPointers();
|
1377: LOG(FATAL) << DebugStreamPointers()
|
1379: << sub_stream->DebugStreamPointers();
|
1401: CheckError(parent_->CreateStreamDependency(this, other));
|
1404: LOG(INFO) << DebugStreamPointers() << " did not wait for "
|
1405: << other->DebugStreamPointers();
|
1422: LOG(INFO) << DebugStreamPointers() << " did not wait for an event.";
|
4406: LOG(INFO) << DebugStreamPointers() << " unable to initialize RNG";
|
4418: LOG(INFO) << DebugStreamPointers()
|
4433: LOG(INFO) << DebugStreamPointers()
|
4448: LOG(INFO) << DebugStreamPointers()
|
4462: LOG(INFO) << DebugStreamPointers()
|
4477: LOG(INFO) << DebugStreamPointers()
|
4492: LOG(INFO) << DebugStreamPointers()
|
4829: LOG(INFO) << DebugStreamPointers()
|
4841: LOG(INFO) << DebugStreamPointers()
|
4853: LOG(INFO) << DebugStreamPointers()
|
4871: LOG(INFO) << DebugStreamPointers()
|
4887: LOG(INFO) << DebugStreamPointers()
|
4902: LOG(INFO) << DebugStreamPointers()
|
4917: LOG(INFO) << DebugStreamPointers()
|
4933: LOG(INFO) << DebugStreamPointers()
|
4949: LOG(INFO) << DebugStreamPointers()
|
4977: LOG(INFO) << DebugStreamPointers() << " " << status;
|
github.com/kubernetes/kubernetes:vendor/github.com/docker/docker/api/types/client.go: [ master, ] |
---|
33: Stream bool
|
github.com/google/filament:third_party/spirv-tools/external/spirv-headers/include/spirv/unified1/spirv.json: [ master, ] |
---|
462: "Stream": 29,
|
793: "GeometryStreams": 54,
|
1110: "OpEmitStreamVertex": 220,
|
1111: "OpEndStreamPrimitive": 221,
|
1322: "OpTypeAvcImeResultSingleReferenceStreamoutINTEL": 5707,
|
1323: "OpTypeAvcImeResultDualReferenceStreamoutINTEL": 5708,
|
1324: "OpTypeAvcImeSingleReferenceStreaminINTEL": 5709,
|
1325: "OpTypeAvcImeDualReferenceStreaminINTEL": 5710,
|
1374: "OpSubgroupAvcImeEvaluateWithSingleReferenceStreaminINTEL": 5759,
|
1375: "OpSubgroupAvcImeEvaluateWithDualReferenceStreaminINTEL": 5760,
|
1376: "OpSubgroupAvcImeEvaluateWithSingleReferenceStreamoutINTEL": 5761,
|
1377: "OpSubgroupAvcImeEvaluateWithDualReferenceStreamoutINTEL": 5762,
|
1378: "OpSubgroupAvcImeEvaluateWithSingleReferenceStreaminoutINTEL": 5763,
|
1379: "OpSubgroupAvcImeEvaluateWithDualReferenceStreaminoutINTEL": 5764,
|
1381: "OpSubgroupAvcImeGetSingleReferenceStreaminINTEL": 5766,
|
1382: "OpSubgroupAvcImeGetDualReferenceStreaminINTEL": 5767,
|
1383: "OpSubgroupAvcImeStripSingleReferenceStreamoutINTEL": 5768,
|
1384: "OpSubgroupAvcImeStripDualReferenceStreamoutINTEL": 5769,
|
1385: "OpSubgroupAvcImeGetStreamoutSingleReferenceMajorShapeMotionVectorsINTEL": 5770,
|
1386: "OpSubgroupAvcImeGetStreamoutSingleReferenceMajorShapeDistortionsINTEL": 5771,
|
1387: "OpSubgroupAvcImeGetStreamoutSingleReferenceMajorShapeReferenceIdsINTEL": 5772,
|
1388: "OpSubgroupAvcImeGetStreamoutDualReferenceMajorShapeMotionVectorsINTEL": 5773,
|
1389: "OpSubgroupAvcImeGetStreamoutDualReferenceMajorShapeDistortionsINTEL": 5774,
|
1390: "OpSubgroupAvcImeGetStreamoutDualReferenceMajorShapeReferenceIdsINTEL": 5775,
|
github.com/apache/camel:core/camel-endpointdsl/src/generated/java/org/apache/camel/builder/endpoint/dsl/JmsEndpointBuilderFactory.java: [ master, ] |
---|
6634: Stream,
|
1344: default AdvancedJmsEndpointConsumerBuilder artemisStreamingEnabled(
|
1361: default AdvancedJmsEndpointConsumerBuilder artemisStreamingEnabled(
|
3829: default AdvancedJmsEndpointProducerBuilder artemisStreamingEnabled(
|
3846: default AdvancedJmsEndpointProducerBuilder artemisStreamingEnabled(
|
5433: default AdvancedJmsEndpointBuilder artemisStreamingEnabled(
|
5450: default AdvancedJmsEndpointBuilder artemisStreamingEnabled(
|
162: * Map, Object, Stream, Text. By default, Camel would determine which
|
182: * Map, Object, Stream, Text. By default, Camel would determine which
|
2672: * Map, Object, Stream, Text. By default, Camel would determine which
|
2692: * Map, Object, Stream, Text. By default, Camel would determine which
|
5156: * Map, Object, Stream, Text. By default, Camel would determine which
|
5175: * Map, Object, Stream, Text. By default, Camel would determine which
|
3735: * Sets whether StreamMessage type is enabled or not. Message payloads
|
3736: * of streaming kind such as files, InputStream, etc will either by sent
|
3737: * as BytesMessage or StreamMessage. This option controls which kind
|
3741: * chunk is then written to the StreamMessage until no more data.
|
3757: * Sets whether StreamMessage type is enabled or not. Message payloads
|
3758: * of streaming kind such as files, InputStream, etc will either by sent
|
3759: * as BytesMessage or StreamMessage. This option controls which kind
|
3763: * chunk is then written to the StreamMessage until no more data.
|
1341: * @param artemisStreamingEnabled the value to set
|
1345: boolean artemisStreamingEnabled) {
|
1346: doSetProperty("artemisStreamingEnabled", artemisStreamingEnabled);
|
1358: * @param artemisStreamingEnabled the value to set
|
1362: String artemisStreamingEnabled) {
|
1363: doSetProperty("artemisStreamingEnabled", artemisStreamingEnabled);
|
3826: * @param artemisStreamingEnabled the value to set
|
3830: boolean artemisStreamingEnabled) {
|
3831: doSetProperty("artemisStreamingEnabled", artemisStreamingEnabled);
|
3843: * @param artemisStreamingEnabled the value to set
|
3847: String artemisStreamingEnabled) {
|
3848: doSetProperty("artemisStreamingEnabled", artemisStreamingEnabled);
|
5430: * @param artemisStreamingEnabled the value to set
|
5434: boolean artemisStreamingEnabled) {
|
5435: doSetProperty("artemisStreamingEnabled", artemisStreamingEnabled);
|
5447: * @param artemisStreamingEnabled the value to set
|
5451: String artemisStreamingEnabled) {
|
5452: doSetProperty("artemisStreamingEnabled", artemisStreamingEnabled);
|
github.com/apache/camel:core/camel-endpointdsl/src/generated/java/org/apache/camel/builder/endpoint/dsl/AMQPEndpointBuilderFactory.java: [ master, ] |
---|
6636: Stream,
|
1345: default AdvancedAMQPEndpointConsumerBuilder artemisStreamingEnabled(
|
1362: default AdvancedAMQPEndpointConsumerBuilder artemisStreamingEnabled(
|
3831: default AdvancedAMQPEndpointProducerBuilder artemisStreamingEnabled(
|
3848: default AdvancedAMQPEndpointProducerBuilder artemisStreamingEnabled(
|
5435: default AdvancedAMQPEndpointBuilder artemisStreamingEnabled(
|
5452: default AdvancedAMQPEndpointBuilder artemisStreamingEnabled(
|
163: * Map, Object, Stream, Text. By default, Camel would determine which
|
183: * Map, Object, Stream, Text. By default, Camel would determine which
|
2674: * Map, Object, Stream, Text. By default, Camel would determine which
|
2694: * Map, Object, Stream, Text. By default, Camel would determine which
|
5158: * Map, Object, Stream, Text. By default, Camel would determine which
|
5177: * Map, Object, Stream, Text. By default, Camel would determine which
|
3737: * Sets whether StreamMessage type is enabled or not. Message payloads
|
3738: * of streaming kind such as files, InputStream, etc will either by sent
|
3739: * as BytesMessage or StreamMessage. This option controls which kind
|
3743: * chunk is then written to the StreamMessage until no more data.
|
3759: * Sets whether StreamMessage type is enabled or not. Message payloads
|
3760: * of streaming kind such as files, InputStream, etc will either by sent
|
3761: * as BytesMessage or StreamMessage. This option controls which kind
|
3765: * chunk is then written to the StreamMessage until no more data.
|
1342: * @param artemisStreamingEnabled the value to set
|
1346: boolean artemisStreamingEnabled) {
|
1347: doSetProperty("artemisStreamingEnabled", artemisStreamingEnabled);
|
1359: * @param artemisStreamingEnabled the value to set
|
1363: String artemisStreamingEnabled) {
|
1364: doSetProperty("artemisStreamingEnabled", artemisStreamingEnabled);
|
3828: * @param artemisStreamingEnabled the value to set
|
3832: boolean artemisStreamingEnabled) {
|
3833: doSetProperty("artemisStreamingEnabled", artemisStreamingEnabled);
|
3845: * @param artemisStreamingEnabled the value to set
|
3849: String artemisStreamingEnabled) {
|
3850: doSetProperty("artemisStreamingEnabled", artemisStreamingEnabled);
|
5432: * @param artemisStreamingEnabled the value to set
|
5436: boolean artemisStreamingEnabled) {
|
5437: doSetProperty("artemisStreamingEnabled", artemisStreamingEnabled);
|
5449: * @param artemisStreamingEnabled the value to set
|
5453: String artemisStreamingEnabled) {
|
5454: doSetProperty("artemisStreamingEnabled", artemisStreamingEnabled);
|
github.com/apache/camel:core/camel-endpointdsl/src/generated/java/org/apache/camel/builder/endpoint/dsl/ActiveMQEndpointBuilderFactory.java: [ master, ] |
---|
6658: Stream,
|
1351: default AdvancedActiveMQEndpointConsumerBuilder artemisStreamingEnabled(
|
1368: default AdvancedActiveMQEndpointConsumerBuilder artemisStreamingEnabled(
|
3844: default AdvancedActiveMQEndpointProducerBuilder artemisStreamingEnabled(
|
3861: default AdvancedActiveMQEndpointProducerBuilder artemisStreamingEnabled(
|
5451: default AdvancedActiveMQEndpointBuilder artemisStreamingEnabled(
|
5468: default AdvancedActiveMQEndpointBuilder artemisStreamingEnabled(
|
165: * Map, Object, Stream, Text. By default, Camel would determine which
|
185: * Map, Object, Stream, Text. By default, Camel would determine which
|
2681: * Map, Object, Stream, Text. By default, Camel would determine which
|
2701: * Map, Object, Stream, Text. By default, Camel would determine which
|
5173: * Map, Object, Stream, Text. By default, Camel would determine which
|
5193: * Map, Object, Stream, Text. By default, Camel would determine which
|
3750: * Sets whether StreamMessage type is enabled or not. Message payloads
|
3751: * of streaming kind such as files, InputStream, etc will either by sent
|
3752: * as BytesMessage or StreamMessage. This option controls which kind
|
3756: * chunk is then written to the StreamMessage until no more data.
|
3772: * Sets whether StreamMessage type is enabled or not. Message payloads
|
3773: * of streaming kind such as files, InputStream, etc will either by sent
|
3774: * as BytesMessage or StreamMessage. This option controls which kind
|
3778: * chunk is then written to the StreamMessage until no more data.
|
1348: * @param artemisStreamingEnabled the value to set
|
1352: boolean artemisStreamingEnabled) {
|
1353: doSetProperty("artemisStreamingEnabled", artemisStreamingEnabled);
|
1365: * @param artemisStreamingEnabled the value to set
|
1369: String artemisStreamingEnabled) {
|
1370: doSetProperty("artemisStreamingEnabled", artemisStreamingEnabled);
|
3841: * @param artemisStreamingEnabled the value to set
|
3845: boolean artemisStreamingEnabled) {
|
3846: doSetProperty("artemisStreamingEnabled", artemisStreamingEnabled);
|
3858: * @param artemisStreamingEnabled the value to set
|
3862: String artemisStreamingEnabled) {
|
3863: doSetProperty("artemisStreamingEnabled", artemisStreamingEnabled);
|
5448: * @param artemisStreamingEnabled the value to set
|
5452: boolean artemisStreamingEnabled) {
|
5453: doSetProperty("artemisStreamingEnabled", artemisStreamingEnabled);
|
5465: * @param artemisStreamingEnabled the value to set
|
5469: String artemisStreamingEnabled) {
|
5470: doSetProperty("artemisStreamingEnabled", artemisStreamingEnabled);
|
github.com/grpc/grpc-go:internal/transport/transport.go: [ master, ] |
---|
237: type Stream struct {
|
143: closeStream func(error) // Closes the client transport stream with the given error and nil trailer metadata.
|
636: NewStream(ctx context.Context, callHdr *CallHdr) (*Stream, error)
|
642: CloseStream(stream *Stream, err error)
|
519: MaxStreams uint32
|
676: HandleStreams(func(*Stream), func(context.Context, string) context.Context)
|
750: errStreamDrain = status.Error(codes.Unavailable, "the connection is draining")
|
753: errStreamDone = errors.New("the stream is done")
|
790: lastStreamCreatedTime int64
|
236: // Stream represents an RPC in the transport layer.
|
239: st ServerTransport // nil for client side Stream
|
240: ct *http2Client // nil for server side Stream
|
242: cancel context.CancelFunc // always nil for client side Stream
|
293: func (s *Stream) isHeaderSent() bool {
|
299: func (s *Stream) updateHeaderSent() bool {
|
303: func (s *Stream) swapState(st streamState) streamState {
|
307: func (s *Stream) compareAndSwapState(oldState, newState streamState) bool {
|
311: func (s *Stream) getState() streamState {
|
315: func (s *Stream) waitOnHeader() {
|
335: func (s *Stream) RecvCompress() string {
|
341: func (s *Stream) SetSendCompress(str string) {
|
347: func (s *Stream) Done() <-chan struct{} {
|
359: func (s *Stream) Header() (metadata.MD, error) {
|
375: func (s *Stream) TrailersOnly() bool {
|
385: func (s *Stream) Trailer() metadata.MD {
|
395: func (s *Stream) ContentSubtype() string {
|
400: func (s *Stream) Context() context.Context {
|
405: func (s *Stream) Method() string {
|
412: func (s *Stream) Status() *status.Status {
|
419: func (s *Stream) SetHeader(md metadata.MD) error {
|
435: func (s *Stream) SendHeader(md metadata.MD) error {
|
442: func (s *Stream) SetTrailer(md metadata.MD) error {
|
455: func (s *Stream) write(m recvMsg) {
|
460: func (s *Stream) Read(p []byte) (n int, err error) {
|
469: // tranportReader reads all the data available for this Stream from the transport and
|
492: func (s *Stream) BytesReceived() bool {
|
498: func (s *Stream) Unprocessed() bool {
|
502: // GoString is implemented by Stream so context.String() won't
|
504: func (s *Stream) GoString() string {
|
633: Write(s *Stream, hdr []byte, data []byte, opts *Options) error
|
635: // NewStream creates a Stream for an RPC.
|
673: // Write methods for a given Stream will be called serially.
|
680: WriteHeader(s *Stream, md metadata.MD) error
|
684: Write(s *Stream, hdr []byte, data []byte, opts *Options) error
|
688: WriteStatus(s *Stream, st *status.Status) error
|
168: if r.closeStream != nil {
|
187: // closeStream writes its error parameter to r.recv as a recvMsg.
|
198: // was not marked as done when trailer is received. This closeStream
|
204: r.closeStream(ContextErr(r.ctx.Err()))
|
231: streamWriteDone // EndStream sent
|
232: streamReadDone // EndStream received
|
325: s.ct.CloseStream(s, ContextErr(s.ctx.Err()))
|
326: // headerChan could possibly not be closed yet if closeStream raced
|
625: // accepting new RPCs and NewStream will return error. Once all streams are
|
638: // CloseStream clears the footprint of a stream when the stream is
|
640: // CloseStream is called. Must be called when a stream is finished
|
675: // HandleStreams receives incoming streams using the given handler.
|
747: // errStreamDrain indicates that the stream is rejected because the
|
751: // errStreamDone is returned from write at the client side to indiacte application
|
787: // lastStreamCreatedTime stores the timestamp that the last stream gets created. It is of int64 type
|
github.com/tensorflow/fold:tensorflow/tensorflow/stream_executor/stream.cc: [ master, ] |
---|
236: Stream::Stream(StreamExecutor *parent)
|
245: Stream::Stream(StreamExecutor *parent,
|
255: Stream::~Stream() {
|
1793: Stream *Stream::GetOrCreateSubStream() {
|
1810: void Stream::ReturnSubStream(Stream *sub_stream) {
|
195: // there are on Stream and how many parameters they each have.
|
196: string CallStr(const char *function_name, Stream *stream,
|
202: string str = port::StrCat("Called Stream::", function_name, "(");
|
265: Stream &Stream::Init() {
|
284: Stream &Stream::InitTimer(Timer *timer) {
|
295: Stream &Stream::InitWithTimer(Timer *timer) {
|
301: Stream &Stream::ThenRecordEvent(Event *event) {
|
314: Stream &Stream::ThenBatchNormalizationForward(
|
342: Stream &Stream::ThenBatchNormalizationBackward(
|
364: Stream &Stream::ThenBatchNormalizationForward(
|
392: Stream &Stream::ThenBatchNormalizationBackward(
|
415: Stream &Stream::ThenFusedConvolveWithScratch(
|
448: Stream &Stream::ThenFusedConvolveWithScratch(
|
482: Stream &Stream::ThenFusedConvolveWithScratch(
|
515: Stream &Stream::ThenConvolveWithScratch(
|
542: Stream &Stream::ThenConvolveWithScratch(
|
569: Stream &Stream::ThenFusedConvolveWithAlgorithm(
|
607: Stream &Stream::ThenFusedConvolveWithAlgorithm(
|
646: Stream &Stream::ThenFusedConvolveWithAlgorithm(
|
684: Stream &Stream::ThenConvolveWithAlgorithm(
|
715: Stream &Stream::ThenConvolveWithAlgorithm(
|
746: Stream &Stream::ThenFusedConvolve(
|
764: Stream &Stream::ThenConvolve(
|
778: Stream &Stream::ThenConvolveQuantized(
|
808: Stream &Stream::ThenConvolveQuantized(
|
838: Stream &Stream::ThenSeparableConvolve(
|
865: Stream &Stream::ThenConvolveBackwardDataWithScratch(
|
893: Stream &Stream::ThenConvolveBackwardDataWithAlgorithm(
|
926: Stream &Stream::ThenConvolveBackwardDataWithAlgorithm(
|
959: Stream &Stream::ThenConvolveBackwardDataWithScratch(
|
987: Stream &Stream::ThenConvolveBackwardData(
|
1001: Stream &Stream::ThenConvolveBackwardFilterWithScratch(
|
1029: Stream &Stream::ThenConvolveBackwardFilterWithAlgorithm(
|
1062: Stream &Stream::ThenConvolveBackwardFilterWithScratch(
|
1090: Stream &Stream::ThenConvolveBackwardFilterWithAlgorithm(
|
1123: Stream &Stream::ThenConvolveBackwardFilter(
|
1138: Stream &Stream::ThenConvolveBackwardBiasImpl(
|
1158: Stream &Stream::ThenConvolveBackwardBias(
|
1167: Stream &Stream::ThenConvolveBackwardBias(
|
1176: Stream &Stream::ThenConvolveBackwardBias(
|
1185: Stream &Stream::ThenMatMul(const DeviceMemory<float> &input_data,
|
1204: Stream &Stream::ThenMatMulQuantized(
|
1226: Stream &Stream::ThenMatMulQuantized(
|
1248: Stream &Stream::ThenBiasAdd(const DeviceMemory<float> &input_data,
|
1266: Stream &Stream::ThenPoolForward(
|
1290: Stream &Stream::ThenPoolForward(
|
1311: Stream &Stream::ThenPoolForward(
|
1332: Stream &Stream::ThenPoolBackward(
|
1359: Stream &Stream::ThenPoolBackward(
|
1383: Stream &Stream::ThenPoolBackward(
|
1407: Stream &Stream::ThenNormalize(
|
1423: Stream &Stream::ThenNormalizeWithDimensions(
|
1441: Stream &Stream::ThenNormalizeBackwardWithDimensions(
|
1463: Stream &Stream::ThenActivate(dnn::ActivationMode activation_mode,
|
1471: Stream &Stream::ThenActivateWithOptions(dnn::ActivationMode activation_mode,
|
1490: Stream &Stream::ThenDepthConcatenate(
|
1520: Stream &Stream::ThenSpaceConcatenate(
|
1567: Stream &Stream::ThenReshape(const dnn::BatchDescriptor &input_dimensions,
|
1585: Stream &Stream::ThenDepthToSpace(
|
1606: Stream &Stream::ThenSpaceToDepth(
|
1627: Stream &Stream::ThenElementwiseOperate(
|
1648: Stream &Stream::ThenElementwiseOperateScaledQuantized(
|
1671: Stream &Stream::ThenXYPad(const dnn::BatchDescriptor &dimensions,
|
1690: Stream &Stream::ThenXYSlice(const dnn::BatchDescriptor &dimensions,
|
1711: Stream &Stream::ThenXYBroadcast(const dnn::BatchDescriptor &dimensions,
|
1729: Stream &Stream::ThenMemcpyD2HQuantized(
|
1746: Stream &Stream::ThenMemcpyH2DQuantized(
|
1763: Stream &Stream::ThenCopyHostBuffer2Device(
|
1778: Stream &Stream::ThenCopyDevice2HostBuffer(
|
1801: sub_streams_.emplace_back(std::unique_ptr<Stream>{new Stream{parent_}},
|
1803: Stream *sub_stream = sub_streams_.back().first.get();
|
1821: Stream &Stream::ThenStartTimer(Timer *t) {
|
1832: Stream &Stream::ThenStopTimer(Timer *t) {
|
1843: Stream &Stream::ThenWaitFor(Stream *other) {
|
1856: Stream &Stream::ThenWaitFor(Event *event) {
|
1878: // arguments except the first one of Stream* type.
|
1879: Stream &operator()(Stream *stream,
|
1880: bool (blas::BlasSupport::*blas_func)(Stream *, Args...),
|
1887: Stream &Run(Stream *stream,
|
1888: bool (blas::BlasSupport::*blas_func)(Stream *, Args...),
|
1893: Stream &ThenBlasImpl<Args...>::Run(
|
1894: Stream *stream, bool (blas::BlasSupport::*blas_func)(Stream *, Args...),
|
1913: Stream &Stream::ThenBlasAsum(uint64 elem_count, const DeviceMemory<float> &x,
|
1923: Stream &Stream::ThenBlasAsum(uint64 elem_count, const DeviceMemory<double> &x,
|
1933: Stream &Stream::ThenBlasAsum(uint64 elem_count,
|
1944: Stream &Stream::ThenBlasAsum(uint64 elem_count,
|
1955: Stream &Stream::ThenBlasAxpy(uint64 elem_count, float alpha,
|
1967: Stream &Stream::ThenBlasAxpy(uint64 elem_count, double alpha,
|
1979: Stream &Stream::ThenBlasAxpy(uint64 elem_count, std::complex<float> alpha,
|
1993: Stream &Stream::ThenBlasAxpy(uint64 elem_count, std::complex<double> alpha,
|
2007: Stream &Stream::ThenBlasCopy(uint64 elem_count, const DeviceMemory<float> &x,
|
2017: Stream &Stream::ThenBlasCopy(uint64 elem_count, const DeviceMemory<double> &x,
|
2027: Stream &Stream::ThenBlasCopy(uint64 elem_count,
|
2039: Stream &Stream::ThenBlasCopy(uint64 elem_count,
|
2051: Stream &Stream::ThenBlasDot(uint64 elem_count, const DeviceMemory<float> &x,
|
2063: Stream &Stream::ThenBlasDot(uint64 elem_count, const DeviceMemory<double> &x,
|
2075: Stream &Stream::ThenBlasDotc(uint64 elem_count,
|
2091: Stream &Stream::ThenBlasDotc(uint64 elem_count,
|
2107: Stream &Stream::ThenBlasDotu(uint64 elem_count,
|
2123: Stream &Stream::ThenBlasDotu(uint64 elem_count,
|
2139: Stream &Stream::ThenBlasNrm2(uint64 elem_count, const DeviceMemory<float> &x,
|
2149: Stream &Stream::ThenBlasNrm2(uint64 elem_count, const DeviceMemory<double> &x,
|
2159: Stream &Stream::ThenBlasNrm2(uint64 elem_count,
|
2170: Stream &Stream::ThenBlasNrm2(uint64 elem_count,
|
2181: Stream &Stream::ThenBlasRot(uint64 elem_count, DeviceMemory<float> *x, int incx,
|
2193: Stream &Stream::ThenBlasRot(uint64 elem_count, DeviceMemory<double> *x,
|
2205: Stream &Stream::ThenBlasRot(uint64 elem_count,
|
2218: Stream &Stream::ThenBlasRot(uint64 elem_count,
|
2231: Stream &Stream::ThenBlasRotg(DeviceMemory<float> *a, DeviceMemory<float> *b,
|
2240: Stream &Stream::ThenBlasRotg(DeviceMemory<double> *a, DeviceMemory<double> *b,
|
2249: Stream &Stream::ThenBlasRotg(DeviceMemory<std::complex<float>> *a,
|
2261: Stream &Stream::ThenBlasRotg(DeviceMemory<std::complex<double>> *a,
|
2273: Stream &Stream::ThenBlasRotm(uint64 elem_count, DeviceMemory<float> *x,
|
2285: Stream &Stream::ThenBlasRotm(uint64 elem_count, DeviceMemory<double> *x,
|
2297: Stream &Stream::ThenBlasRotmg(DeviceMemory<float> *d1, DeviceMemory<float> *d2,
|
2309: Stream &Stream::ThenBlasRotmg(DeviceMemory<double> *d1,
|
2322: Stream &Stream::ThenBlasScal(uint64 elem_count, float alpha,
|
2330: Stream &Stream::ThenBlasScal(uint64 elem_count, double alpha,
|
2338: Stream &Stream::ThenBlasScal(uint64 elem_count, float alpha,
|
2346: Stream &Stream::ThenBlasScal(uint64 elem_count, double alpha,
|
2354: Stream &Stream::ThenBlasScal(uint64 elem_count, std::complex<float> alpha,
|
2363: Stream &Stream::ThenBlasScal(uint64 elem_count, std::complex<double> alpha,
|
2372: Stream &Stream::ThenBlasSwap(uint64 elem_count, DeviceMemory<float> *x,
|
2382: Stream &Stream::ThenBlasSwap(uint64 elem_count, DeviceMemory<double> *x,
|
2392: Stream &Stream::ThenBlasSwap(uint64 elem_count,
|
2403: Stream &Stream::ThenBlasSwap(uint64 elem_count,
|
2414: Stream &Stream::ThenBlasIamax(uint64 elem_count, const DeviceMemory<float> &x,
|
2424: Stream &Stream::ThenBlasIamax(uint64 elem_count, const DeviceMemory<double> &x,
|
2434: Stream &Stream::ThenBlasIamax(uint64 elem_count,
|
2445: Stream &Stream::ThenBlasIamax(uint64 elem_count,
|
2456: Stream &Stream::ThenBlasIamin(uint64 elem_count, const DeviceMemory<float> &x,
|
2466: Stream &Stream::ThenBlasIamin(uint64 elem_count, const DeviceMemory<double> &x,
|
2476: Stream &Stream::ThenBlasIamin(uint64 elem_count,
|
2487: Stream &Stream::ThenBlasIamin(uint64 elem_count,
|
2498: Stream &Stream::ThenBlasGbmv(blas::Transpose trans, uint64 m, uint64 n,
|
2514: Stream &Stream::ThenBlasGbmv(blas::Transpose trans, uint64 m, uint64 n,
|
2530: Stream &Stream::ThenBlasGbmv(blas::Transpose trans, uint64 m, uint64 n,
|
2550: Stream &Stream::ThenBlasGbmv(blas::Transpose trans, uint64 m, uint64 n,
|
2570: Stream &Stream::ThenBlasGemv(blas::Transpose trans, uint64 m, uint64 n,
|
2585: Stream &Stream::ThenBlasGemv(blas::Transpose trans, uint64 m, uint64 n,
|
2600: Stream &Stream::ThenBlasGemv(blas::Transpose trans, uint64 m, uint64 n,
|
2620: Stream &Stream::ThenBlasGemv(blas::Transpose trans, uint64 m, uint64 n,
|
2640: Stream &Stream::ThenBlasGer(uint64 m, uint64 n, float alpha,
|
2654: Stream &Stream::ThenBlasGer(uint64 m, uint64 n, double alpha,
|
2668: Stream &Stream::ThenBlasGerc(uint64 m, uint64 n, std::complex<float> alpha,
|
2685: Stream &Stream::ThenBlasGerc(uint64 m, uint64 n, std::complex<double> alpha,
|
2702: Stream &Stream::ThenBlasGeru(uint64 m, uint64 n, std::complex<float> alpha,
|
2719: Stream &Stream::ThenBlasGeru(uint64 m, uint64 n, std::complex<double> alpha,
|
2736: Stream &Stream::ThenBlasHbmv(blas::UpperLower uplo, uint64 n, uint64 k,
|
2755: Stream &Stream::ThenBlasHbmv(blas::UpperLower uplo, uint64 n, uint64 k,
|
2774: Stream &Stream::ThenBlasHemv(blas::UpperLower uplo, uint64 n,
|
2793: Stream &Stream::ThenBlasHemv(blas::UpperLower uplo, uint64 n,
|
2812: Stream &Stream::ThenBlasHer(blas::UpperLower uplo, uint64 n, float alpha,
|
2826: Stream &Stream::ThenBlasHer(blas::UpperLower uplo, uint64 n, double alpha,
|
2840: Stream &Stream::ThenBlasHer2(blas::UpperLower uplo, uint64 n,
|
2858: Stream &Stream::ThenBlasHer2(blas::UpperLower uplo, uint64 n,
|
2876: Stream &Stream::ThenBlasHpmv(blas::UpperLower uplo, uint64 n,
|
2894: Stream &Stream::ThenBlasHpmv(blas::UpperLower uplo, uint64 n,
|
2912: Stream &Stream::ThenBlasHpr(blas::UpperLower uplo, uint64 n, float alpha,
|
2924: Stream &Stream::ThenBlasHpr(blas::UpperLower uplo, uint64 n, double alpha,
|
2936: Stream &Stream::ThenBlasHpr2(blas::UpperLower uplo, uint64 n,
|
2953: Stream &Stream::ThenBlasHpr2(blas::UpperLower uplo, uint64 n,
|
2970: Stream &Stream::ThenBlasSbmv(blas::UpperLower uplo, uint64 n, uint64 k,
|
2984: Stream &Stream::ThenBlasSbmv(blas::UpperLower uplo, uint64 n, uint64 k,
|
2998: Stream &Stream::ThenBlasSpmv(blas::UpperLower uplo, uint64 n, float alpha,
|
3012: Stream &Stream::ThenBlasSpmv(blas::UpperLower uplo, uint64 n, double alpha,
|
3026: Stream &Stream::ThenBlasSpr(blas::UpperLower uplo, uint64 n, float alpha,
|
3037: Stream &Stream::ThenBlasSpr(blas::UpperLower uplo, uint64 n, double alpha,
|
3048: Stream &Stream::ThenBlasSpr2(blas::UpperLower uplo, uint64 n, float alpha,
|
3062: Stream &Stream::ThenBlasSpr2(blas::UpperLower uplo, uint64 n, double alpha,
|
3076: Stream &Stream::ThenBlasSymv(blas::UpperLower uplo, uint64 n, float alpha,
|
3090: Stream &Stream::ThenBlasSymv(blas::UpperLower uplo, uint64 n, double alpha,
|
3104: Stream &Stream::ThenBlasSyr(blas::UpperLower uplo, uint64 n, float alpha,
|
3116: Stream &Stream::ThenBlasSyr(blas::UpperLower uplo, uint64 n, double alpha,
|
3128: Stream &Stream::ThenBlasSyr2(blas::UpperLower uplo, uint64 n, float alpha,
|
3142: Stream &Stream::ThenBlasSyr2(blas::UpperLower uplo, uint64 n, double alpha,
|
3156: Stream &Stream::ThenBlasTbmv(blas::UpperLower uplo, blas::Transpose trans,
|
3170: Stream &Stream::ThenBlasTbmv(blas::UpperLower uplo, blas::Transpose trans,
|
3184: Stream &Stream::ThenBlasTbmv(blas::UpperLower uplo, blas::Transpose trans,
|
3199: Stream &Stream::ThenBlasTbmv(blas::UpperLower uplo, blas::Transpose trans,
|
3214: Stream &Stream::ThenBlasTbsv(blas::UpperLower uplo, blas::Transpose trans,
|
3228: Stream &Stream::ThenBlasTbsv(blas::UpperLower uplo, blas::Transpose trans,
|
3242: Stream &Stream::ThenBlasTbsv(blas::UpperLower uplo, blas::Transpose trans,
|
3257: Stream &Stream::ThenBlasTbsv(blas::UpperLower uplo, blas::Transpose trans,
|
3272: Stream &Stream::ThenBlasTpmv(blas::UpperLower uplo, blas::Transpose trans,
|
3285: Stream &Stream::ThenBlasTpmv(blas::UpperLower uplo, blas::Transpose trans,
|
3298: Stream &Stream::ThenBlasTpmv(blas::UpperLower uplo, blas::Transpose trans,
|
3312: Stream &Stream::ThenBlasTpmv(blas::UpperLower uplo, blas::Transpose trans,
|
3326: Stream &Stream::ThenBlasTpsv(blas::UpperLower uplo, blas::Transpose trans,
|
3339: Stream &Stream::ThenBlasTpsv(blas::UpperLower uplo, blas::Transpose trans,
|
3352: Stream &Stream::ThenBlasTpsv(blas::UpperLower uplo, blas::Transpose trans,
|
3366: Stream &Stream::ThenBlasTpsv(blas::UpperLower uplo, blas::Transpose trans,
|
3380: Stream &Stream::ThenBlasTrmv(blas::UpperLower uplo, blas::Transpose trans,
|
3394: Stream &Stream::ThenBlasTrmv(blas::UpperLower uplo, blas::Transpose trans,
|
3408: Stream &Stream::ThenBlasTrmv(blas::UpperLower uplo, blas::Transpose trans,
|
3423: Stream &Stream::ThenBlasTrmv(blas::UpperLower uplo, blas::Transpose trans,
|
3438: Stream &Stream::ThenBlasTrsv(blas::UpperLower uplo, blas::Transpose trans,
|
3452: Stream &Stream::ThenBlasTrsv(blas::UpperLower uplo, blas::Transpose trans,
|
3466: Stream &Stream::ThenBlasTrsv(blas::UpperLower uplo, blas::Transpose trans,
|
3481: Stream &Stream::ThenBlasTrsv(blas::UpperLower uplo, blas::Transpose trans,
|
3496: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3514: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3530: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3546: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3567: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3595: Stream &operator()(Stream *stream,
|
3597: Stream *, Args..., blas::ProfileResult *),
|
3606: Stream &Stream::ThenBlasGemvWithProfiling(
|
3623: Stream &Stream::ThenBlasGemvWithProfiling(
|
3641: Stream &Stream::ThenBlasGemvWithProfiling(
|
3661: Stream &Stream::ThenBlasGemvWithProfiling(
|
3681: Stream &Stream::ThenBlasGemmWithProfiling(
|
3701: Stream &Stream::ThenBlasGemmWithProfiling(
|
3720: Stream &Stream::ThenBlasGemmWithProfiling(
|
3740: Stream &Stream::ThenBlasGemmWithProfiling(
|
3762: Stream &Stream::ThenBlasGemmWithProfiling(
|
3784: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3808: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3829: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3850: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3872: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3897: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3922: Stream &Stream::ThenBlasHemm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
3942: Stream &Stream::ThenBlasHemm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
3962: Stream &Stream::ThenBlasHerk(blas::UpperLower uplo, blas::Transpose trans,
|
3977: Stream &Stream::ThenBlasHerk(blas::UpperLower uplo, blas::Transpose trans,
|
3992: Stream &Stream::ThenBlasHer2k(blas::UpperLower uplo, blas::Transpose trans,
|
4011: Stream &Stream::ThenBlasHer2k(blas::UpperLower uplo, blas::Transpose trans,
|
4030: Stream &Stream::ThenBlasSymm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
4046: Stream &Stream::ThenBlasSymm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
4062: Stream &Stream::ThenBlasSymm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
4082: Stream &Stream::ThenBlasSymm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
4102: Stream &Stream::ThenBlasSyrk(blas::UpperLower uplo, blas::Transpose trans,
|
4116: Stream &Stream::ThenBlasSyrk(blas::UpperLower uplo, blas::Transpose trans,
|
4130: Stream &Stream::ThenBlasSyrk(blas::UpperLower uplo, blas::Transpose trans,
|
4146: Stream &Stream::ThenBlasSyrk(blas::UpperLower uplo, blas::Transpose trans,
|
4162: Stream &Stream::ThenBlasSyr2k(blas::UpperLower uplo, blas::Transpose trans,
|
4178: Stream &Stream::ThenBlasSyr2k(blas::UpperLower uplo, blas::Transpose trans,
|
4194: Stream &Stream::ThenBlasSyr2k(blas::UpperLower uplo, blas::Transpose trans,
|
4214: Stream &Stream::ThenBlasSyr2k(blas::UpperLower uplo, blas::Transpose trans,
|
4234: Stream &Stream::ThenBlasTrmm(blas::Side side, blas::UpperLower uplo,
|
4249: Stream &Stream::ThenBlasTrmm(blas::Side side, blas::UpperLower uplo,
|
4264: Stream &Stream::ThenBlasTrmm(blas::Side side, blas::UpperLower uplo,
|
4281: Stream &Stream::ThenBlasTrmm(blas::Side side, blas::UpperLower uplo,
|
4298: Stream &Stream::ThenBlasTrsm(blas::Side side, blas::UpperLower uplo,
|
4313: Stream &Stream::ThenBlasTrsm(blas::Side side, blas::UpperLower uplo,
|
4328: Stream &Stream::ThenBlasTrsm(blas::Side side, blas::UpperLower uplo,
|
4345: Stream &Stream::ThenBlasTrsm(blas::Side side, blas::UpperLower uplo,
|
4362: Stream &Stream::ThenBlasGemmBatched(
|
4373: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4394: Stream &Stream::ThenBlasGemmBatched(
|
4405: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4426: Stream &Stream::ThenBlasGemmBatched(
|
4439: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4465: Stream &Stream::ThenBlasGemmBatched(
|
4478: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4504: Stream &Stream::ThenSetRngSeed(const uint8 *seed, uint64 seed_bytes) {
|
4522: Stream &Stream::ThenPopulateRandUniform(DeviceMemory<float> *values) {
|
4537: Stream &Stream::ThenPopulateRandGaussian(float mean, float sd,
|
4553: Stream &Stream::ThenPopulateRandGaussian(double mean, double sd,
|
4569: Stream &Stream::ThenPopulateRandUniform(DeviceMemory<double> *values) {
|
4584: Stream &Stream::ThenPopulateRandUniform(
|
4600: Stream &Stream::ThenPopulateRandUniform(
|
4617: Stream &Stream::ThenMemcpy(void *host_dst, const DeviceMemoryBase &gpu_src,
|
4630: Stream &Stream::ThenMemcpy(DeviceMemoryBase *gpu_dst, const void *host_src,
|
4643: Stream &Stream::ThenMemcpy(DeviceMemoryBase *gpu_dst,
|
4656: Stream &Stream::ThenMemZero(DeviceMemoryBase *location, uint64 size) {
|
4668: Stream &Stream::ThenMemset32(DeviceMemoryBase *location, uint32 pattern,
|
4682: Stream &Stream::ThenRnnForward(
|
4714: Stream &Stream::ThenRnnForward(
|
4747: Stream &Stream::ThenRnnBackward(
|
4788: Stream &Stream::ThenRnnBackward(
|
4830: Stream &Stream::ThenTransformTensor(const dnn::BatchDescriptor &input_desc,
|
4851: Stream &Stream::ThenDoHostCallbackForTest(std::function<void()> callback) {
|
4857: Stream &Stream::ThenDoHostCallback(std::function<void()> callback) {
|
4869: Stream &Stream::ThenFft(fft::Plan *plan,
|
4886: Stream &Stream::ThenFft(fft::Plan *plan,
|
4903: Stream &Stream::ThenFft(fft::Plan *plan, const DeviceMemory<float> &input,
|
4919: Stream &Stream::ThenFft(fft::Plan *plan, const DeviceMemory<double> &input,
|
4935: Stream &Stream::ThenFft(fft::Plan *plan,
|
4952: Stream &Stream::ThenFft(fft::Plan *plan,
|
4971: Stream &Stream::ThenEnqueueOnBackgroundThread(
|
4983: bool Stream::BlockHostUntilDone() {
|
246: internal::StreamInterface *implementation)
|
261: parent_->DeallocateStream(this);
|
273: if (parent_->AllocateStream(this)) {
|
801: << "attempting to perform DNN operation using StreamExecutor "
|
831: << "attempting to perform DNN operation using StreamExecutor "
|
1283: << "attempting to perform DNN operation using StreamExecutor "
|
1352: << "attempting to perform DNN operation using StreamExecutor "
|
1902: << "attempting to perform BLAS operation using StreamExecutor "
|
4530: LOG(INFO) << "attempting to perform RNG operation using StreamExecutor "
|
4546: LOG(INFO) << "attempting to perform RNG operation using StreamExecutor "
|
4562: LOG(INFO) << "attempting to perform RNG operation using StreamExecutor "
|
4577: LOG(INFO) << "attempting to perform RNG operation using StreamExecutor "
|
4593: LOG(INFO) << "attempting to perform RNG operation using StreamExecutor "
|
4610: << " attempting to perform RNG operation using StreamExecutor "
|
4879: LOG(INFO) << "attempting to perform FFT operation using StreamExecutor "
|
4896: LOG(INFO) << "attempting to perform FFT operation using StreamExecutor "
|
4912: LOG(INFO) << "attempting to perform FFT operation using StreamExecutor "
|
4928: LOG(INFO) << "attempting to perform FFT operation using StreamExecutor "
|
4945: LOG(INFO) << "attempting to perform FFT operation using StreamExecutor "
|
4962: LOG(INFO) << "attempting to perform FFT operation using StreamExecutor "
|
4972: std::function<void(StreamExecutor *)> task) {
|
4975: StreamExecutor *stream_executor = this->parent_;
|
238: implementation_(parent->implementation()->GetStreamImplementation()),
|
1848: CheckError(parent_->CreateStreamDependency(this, other));
|
github.com/tensorflow/haskell:third_party/tensorflow/tensorflow/stream_executor/stream.cc: [ master, ] |
---|
250: Stream::Stream(StreamExecutor *parent)
|
259: Stream::Stream(StreamExecutor *parent,
|
269: Stream::~Stream() {
|
1880: Stream *Stream::GetOrCreateSubStream() {
|
1932: void Stream::ReturnSubStream(Stream *sub_stream) {
|
5491: std::string Stream::DebugStreamPointers() const {
|
208: // there are on Stream and how many parameters they each have.
|
209: std::string CallStr(const char *function_name, Stream *stream,
|
216: " Called Stream::", function_name, "(");
|
286: port::Status Stream::RefreshStatus() {
|
297: Stream &Stream::Init() {
|
316: Stream &Stream::InitTimer(Timer *timer) {
|
327: Stream &Stream::InitWithTimer(Timer *timer) {
|
333: Stream &Stream::ThenRecordEvent(Event *event) {
|
346: Stream &Stream::ThenBatchNormalizationForward(
|
377: Stream &Stream::ThenBatchNormalizationBackward(
|
402: Stream &Stream::ThenBatchNormalizationForward(
|
433: Stream &Stream::ThenBatchNormalizationBackward(
|
460: Stream &Stream::ThenFusedConvolveWithAlgorithm(
|
498: Stream &Stream::ThenFusedConvolveWithAlgorithm(
|
536: Stream &Stream::ThenFusedConvolveWithAlgorithm(
|
575: Stream &Stream::ThenFusedConvolveWithAlgorithm(
|
613: Stream &Stream::ThenFusedConvolveWithAlgorithm(
|
651: Stream &Stream::ThenConvolveWithAlgorithm(
|
693: Stream &Stream::ThenConvolveWithAlgorithm(
|
735: Stream &Stream::ThenConvolveWithAlgorithm(
|
777: Stream &Stream::ThenConvolveWithAlgorithm(
|
819: Stream &Stream::ThenConvolveWithAlgorithm(
|
861: Stream &Stream::ThenConvolve(
|
876: Stream &Stream::ThenConvolveQuantized(
|
906: Stream &Stream::ThenConvolveQuantized(
|
936: Stream &Stream::ThenSeparableConvolve(
|
963: Stream &Stream::ThenConvolveBackwardDataWithAlgorithm(
|
1008: Stream &Stream::ThenConvolveBackwardDataWithAlgorithm(
|
1053: Stream &Stream::ThenConvolveBackwardDataWithAlgorithm(
|
1098: Stream &Stream::ThenConvolveBackwardFilterWithAlgorithm(
|
1143: Stream &Stream::ThenConvolveBackwardFilterWithAlgorithm(
|
1188: Stream &Stream::ThenConvolveBackwardFilterWithAlgorithm(
|
1234: Stream &Stream::ThenConvolveBackwardBiasImpl(
|
1254: Stream &Stream::ThenConvolveBackwardBias(
|
1263: Stream &Stream::ThenConvolveBackwardBias(
|
1272: Stream &Stream::ThenConvolveBackwardBias(
|
1281: Stream &Stream::ThenMatMul(const DeviceMemory<float> &input_data,
|
1300: Stream &Stream::ThenMatMulQuantized(
|
1322: Stream &Stream::ThenMatMulQuantized(
|
1344: Stream &Stream::ThenBiasAdd(const DeviceMemory<float> &input_data,
|
1362: Stream &Stream::ThenPoolForward(
|
1387: Stream &Stream::ThenPoolForward(
|
1409: Stream &Stream::ThenPoolForward(
|
1432: Stream &Stream::ThenPoolForward(
|
1454: Stream &Stream::ThenPoolBackward(
|
1484: Stream &Stream::ThenPoolBackward(
|
1511: Stream &Stream::ThenPoolBackward(
|
1538: Stream &Stream::ThenNormalizeWithDimensions(
|
1556: Stream &Stream::ThenNormalizeBackwardWithDimensions(
|
1580: Stream &Stream::ThenActivate(dnn::ActivationMode activation_mode,
|
1588: Stream &Stream::ThenActivateWithOptions(dnn::ActivationMode activation_mode,
|
1607: Stream &Stream::ThenDepthConcatenate(
|
1637: Stream &Stream::ThenSpaceConcatenate(
|
1684: Stream &Stream::ThenReshape(const dnn::BatchDescriptor &input_dimensions,
|
1702: Stream &Stream::ThenDepthToSpace(
|
1723: Stream &Stream::ThenSpaceToDepth(
|
1744: Stream &Stream::ThenElementwiseOperate(
|
1765: Stream &Stream::ThenElementwiseOperateScaledQuantized(
|
1788: Stream &Stream::ThenXYPad(const dnn::BatchDescriptor &dimensions,
|
1807: Stream &Stream::ThenXYSlice(const dnn::BatchDescriptor &dimensions,
|
1828: Stream &Stream::ThenXYBroadcast(const dnn::BatchDescriptor &dimensions,
|
1846: Stream &Stream::ThenMemcpyD2HQuantized(
|
1863: Stream &Stream::ThenMemcpyH2DQuantized(
|
1881: // Do not destroy bad streams when holding mu_ because ~Stream() may
|
1883: std::vector<std::unique_ptr<Stream>> bad_streams;
|
1890: std::pair<std::unique_ptr<Stream>, bool> &pair = sub_streams_[index];
|
1893: Stream *sub_stream = pair.first.get();
|
1919: sub_streams_.emplace_back(std::unique_ptr<Stream>{new Stream{parent_}},
|
1921: Stream *sub_stream = sub_streams_.back().first.get();
|
1933: // Do not destroy bad streams when holding mu_ because ~Stream() may
|
1935: std::unique_ptr<Stream> bad_stream;
|
1941: std::pair<std::unique_ptr<Stream>, bool> &pair = sub_streams_[index];
|
1972: Stream &Stream::ThenStartTimer(Timer *t) {
|
1984: Stream &Stream::ThenStopTimer(Timer *t) {
|
1996: Stream &Stream::ThenWaitFor(Stream *other) {
|
2010: Stream &Stream::ThenWaitFor(Event *event) {
|
2032: // arguments except the first one of Stream* type.
|
2033: Stream &operator()(Stream *stream,
|
2034: bool (blas::BlasSupport::*blas_func)(Stream *, Args...),
|
2041: Stream &Run(Stream *stream,
|
2042: bool (blas::BlasSupport::*blas_func)(Stream *, Args...),
|
2047: Stream &ThenBlasImpl<Args...>::Run(
|
2048: Stream *stream, bool (blas::BlasSupport::*blas_func)(Stream *, Args...),
|
2067: Stream &Stream::ThenBlasAsum(uint64 elem_count, const DeviceMemory<float> &x,
|
2077: Stream &Stream::ThenBlasAsum(uint64 elem_count, const DeviceMemory<double> &x,
|
2087: Stream &Stream::ThenBlasAsum(uint64 elem_count,
|
2098: Stream &Stream::ThenBlasAsum(uint64 elem_count,
|
2109: Stream &Stream::ThenBlasAxpy(uint64 elem_count, float alpha,
|
2121: Stream &Stream::ThenBlasAxpy(uint64 elem_count, double alpha,
|
2133: Stream &Stream::ThenBlasAxpy(uint64 elem_count, std::complex<float> alpha,
|
2147: Stream &Stream::ThenBlasAxpy(uint64 elem_count, std::complex<double> alpha,
|
2161: Stream &Stream::ThenBlasCopy(uint64 elem_count, const DeviceMemory<float> &x,
|
2171: Stream &Stream::ThenBlasCopy(uint64 elem_count, const DeviceMemory<double> &x,
|
2181: Stream &Stream::ThenBlasCopy(uint64 elem_count,
|
2193: Stream &Stream::ThenBlasCopy(uint64 elem_count,
|
2205: Stream &Stream::ThenBlasDot(uint64 elem_count, const DeviceMemory<float> &x,
|
2217: Stream &Stream::ThenBlasDot(uint64 elem_count, const DeviceMemory<double> &x,
|
2229: Stream &Stream::ThenBlasDotc(uint64 elem_count,
|
2245: Stream &Stream::ThenBlasDotc(uint64 elem_count,
|
2261: Stream &Stream::ThenBlasDotu(uint64 elem_count,
|
2277: Stream &Stream::ThenBlasDotu(uint64 elem_count,
|
2293: Stream &Stream::ThenBlasNrm2(uint64 elem_count, const DeviceMemory<float> &x,
|
2303: Stream &Stream::ThenBlasNrm2(uint64 elem_count, const DeviceMemory<double> &x,
|
2313: Stream &Stream::ThenBlasNrm2(uint64 elem_count,
|
2324: Stream &Stream::ThenBlasNrm2(uint64 elem_count,
|
2335: Stream &Stream::ThenBlasRot(uint64 elem_count, DeviceMemory<float> *x, int incx,
|
2347: Stream &Stream::ThenBlasRot(uint64 elem_count, DeviceMemory<double> *x,
|
2359: Stream &Stream::ThenBlasRot(uint64 elem_count,
|
2372: Stream &Stream::ThenBlasRot(uint64 elem_count,
|
2385: Stream &Stream::ThenBlasRotg(DeviceMemory<float> *a, DeviceMemory<float> *b,
|
2394: Stream &Stream::ThenBlasRotg(DeviceMemory<double> *a, DeviceMemory<double> *b,
|
2403: Stream &Stream::ThenBlasRotg(DeviceMemory<std::complex<float>> *a,
|
2415: Stream &Stream::ThenBlasRotg(DeviceMemory<std::complex<double>> *a,
|
2427: Stream &Stream::ThenBlasRotm(uint64 elem_count, DeviceMemory<float> *x,
|
2439: Stream &Stream::ThenBlasRotm(uint64 elem_count, DeviceMemory<double> *x,
|
2451: Stream &Stream::ThenBlasRotmg(DeviceMemory<float> *d1, DeviceMemory<float> *d2,
|
2463: Stream &Stream::ThenBlasRotmg(DeviceMemory<double> *d1,
|
2476: Stream &Stream::ThenBlasScal(uint64 elem_count, float alpha,
|
2484: Stream &Stream::ThenBlasScal(uint64 elem_count, double alpha,
|
2492: Stream &Stream::ThenBlasScal(uint64 elem_count, float alpha,
|
2500: Stream &Stream::ThenBlasScal(uint64 elem_count, double alpha,
|
2508: Stream &Stream::ThenBlasScal(uint64 elem_count, std::complex<float> alpha,
|
2517: Stream &Stream::ThenBlasScal(uint64 elem_count, std::complex<double> alpha,
|
2526: Stream &Stream::ThenBlasSwap(uint64 elem_count, DeviceMemory<float> *x,
|
2536: Stream &Stream::ThenBlasSwap(uint64 elem_count, DeviceMemory<double> *x,
|
2546: Stream &Stream::ThenBlasSwap(uint64 elem_count,
|
2557: Stream &Stream::ThenBlasSwap(uint64 elem_count,
|
2568: Stream &Stream::ThenBlasIamax(uint64 elem_count, const DeviceMemory<float> &x,
|
2578: Stream &Stream::ThenBlasIamax(uint64 elem_count, const DeviceMemory<double> &x,
|
2588: Stream &Stream::ThenBlasIamax(uint64 elem_count,
|
2599: Stream &Stream::ThenBlasIamax(uint64 elem_count,
|
2610: Stream &Stream::ThenBlasIamin(uint64 elem_count, const DeviceMemory<float> &x,
|
2620: Stream &Stream::ThenBlasIamin(uint64 elem_count, const DeviceMemory<double> &x,
|
2630: Stream &Stream::ThenBlasIamin(uint64 elem_count,
|
2641: Stream &Stream::ThenBlasIamin(uint64 elem_count,
|
2652: Stream &Stream::ThenBlasGbmv(blas::Transpose trans, uint64 m, uint64 n,
|
2668: Stream &Stream::ThenBlasGbmv(blas::Transpose trans, uint64 m, uint64 n,
|
2684: Stream &Stream::ThenBlasGbmv(blas::Transpose trans, uint64 m, uint64 n,
|
2704: Stream &Stream::ThenBlasGbmv(blas::Transpose trans, uint64 m, uint64 n,
|
2724: Stream &Stream::ThenBlasGemv(blas::Transpose trans, uint64 m, uint64 n,
|
2739: Stream &Stream::ThenBlasGemv(blas::Transpose trans, uint64 m, uint64 n,
|
2754: Stream &Stream::ThenBlasGemv(blas::Transpose trans, uint64 m, uint64 n,
|
2774: Stream &Stream::ThenBlasGemv(blas::Transpose trans, uint64 m, uint64 n,
|
2794: Stream &Stream::ThenBlasGer(uint64 m, uint64 n, float alpha,
|
2808: Stream &Stream::ThenBlasGer(uint64 m, uint64 n, double alpha,
|
2822: Stream &Stream::ThenBlasGerc(uint64 m, uint64 n, std::complex<float> alpha,
|
2839: Stream &Stream::ThenBlasGerc(uint64 m, uint64 n, std::complex<double> alpha,
|
2856: Stream &Stream::ThenBlasGeru(uint64 m, uint64 n, std::complex<float> alpha,
|
2873: Stream &Stream::ThenBlasGeru(uint64 m, uint64 n, std::complex<double> alpha,
|
2890: Stream &Stream::ThenBlasHbmv(blas::UpperLower uplo, uint64 n, uint64 k,
|
2909: Stream &Stream::ThenBlasHbmv(blas::UpperLower uplo, uint64 n, uint64 k,
|
2928: Stream &Stream::ThenBlasHemv(blas::UpperLower uplo, uint64 n,
|
2947: Stream &Stream::ThenBlasHemv(blas::UpperLower uplo, uint64 n,
|
2966: Stream &Stream::ThenBlasHer(blas::UpperLower uplo, uint64 n, float alpha,
|
2980: Stream &Stream::ThenBlasHer(blas::UpperLower uplo, uint64 n, double alpha,
|
2994: Stream &Stream::ThenBlasHer2(blas::UpperLower uplo, uint64 n,
|
3012: Stream &Stream::ThenBlasHer2(blas::UpperLower uplo, uint64 n,
|
3030: Stream &Stream::ThenBlasHpmv(blas::UpperLower uplo, uint64 n,
|
3048: Stream &Stream::ThenBlasHpmv(blas::UpperLower uplo, uint64 n,
|
3066: Stream &Stream::ThenBlasHpr(blas::UpperLower uplo, uint64 n, float alpha,
|
3078: Stream &Stream::ThenBlasHpr(blas::UpperLower uplo, uint64 n, double alpha,
|
3090: Stream &Stream::ThenBlasHpr2(blas::UpperLower uplo, uint64 n,
|
3107: Stream &Stream::ThenBlasHpr2(blas::UpperLower uplo, uint64 n,
|
3124: Stream &Stream::ThenBlasSbmv(blas::UpperLower uplo, uint64 n, uint64 k,
|
3138: Stream &Stream::ThenBlasSbmv(blas::UpperLower uplo, uint64 n, uint64 k,
|
3152: Stream &Stream::ThenBlasSpmv(blas::UpperLower uplo, uint64 n, float alpha,
|
3166: Stream &Stream::ThenBlasSpmv(blas::UpperLower uplo, uint64 n, double alpha,
|
3180: Stream &Stream::ThenBlasSpr(blas::UpperLower uplo, uint64 n, float alpha,
|
3191: Stream &Stream::ThenBlasSpr(blas::UpperLower uplo, uint64 n, double alpha,
|
3202: Stream &Stream::ThenBlasSpr2(blas::UpperLower uplo, uint64 n, float alpha,
|
3216: Stream &Stream::ThenBlasSpr2(blas::UpperLower uplo, uint64 n, double alpha,
|
3230: Stream &Stream::ThenBlasSymv(blas::UpperLower uplo, uint64 n, float alpha,
|
3244: Stream &Stream::ThenBlasSymv(blas::UpperLower uplo, uint64 n, double alpha,
|
3258: Stream &Stream::ThenBlasSyr(blas::UpperLower uplo, uint64 n, float alpha,
|
3270: Stream &Stream::ThenBlasSyr(blas::UpperLower uplo, uint64 n, double alpha,
|
3282: Stream &Stream::ThenBlasSyr2(blas::UpperLower uplo, uint64 n, float alpha,
|
3296: Stream &Stream::ThenBlasSyr2(blas::UpperLower uplo, uint64 n, double alpha,
|
3310: Stream &Stream::ThenBlasTbmv(blas::UpperLower uplo, blas::Transpose trans,
|
3324: Stream &Stream::ThenBlasTbmv(blas::UpperLower uplo, blas::Transpose trans,
|
3338: Stream &Stream::ThenBlasTbmv(blas::UpperLower uplo, blas::Transpose trans,
|
3353: Stream &Stream::ThenBlasTbmv(blas::UpperLower uplo, blas::Transpose trans,
|
3368: Stream &Stream::ThenBlasTbsv(blas::UpperLower uplo, blas::Transpose trans,
|
3382: Stream &Stream::ThenBlasTbsv(blas::UpperLower uplo, blas::Transpose trans,
|
3396: Stream &Stream::ThenBlasTbsv(blas::UpperLower uplo, blas::Transpose trans,
|
3411: Stream &Stream::ThenBlasTbsv(blas::UpperLower uplo, blas::Transpose trans,
|
3426: Stream &Stream::ThenBlasTpmv(blas::UpperLower uplo, blas::Transpose trans,
|
3439: Stream &Stream::ThenBlasTpmv(blas::UpperLower uplo, blas::Transpose trans,
|
3452: Stream &Stream::ThenBlasTpmv(blas::UpperLower uplo, blas::Transpose trans,
|
3466: Stream &Stream::ThenBlasTpmv(blas::UpperLower uplo, blas::Transpose trans,
|
3480: Stream &Stream::ThenBlasTpsv(blas::UpperLower uplo, blas::Transpose trans,
|
3493: Stream &Stream::ThenBlasTpsv(blas::UpperLower uplo, blas::Transpose trans,
|
3506: Stream &Stream::ThenBlasTpsv(blas::UpperLower uplo, blas::Transpose trans,
|
3520: Stream &Stream::ThenBlasTpsv(blas::UpperLower uplo, blas::Transpose trans,
|
3534: Stream &Stream::ThenBlasTrmv(blas::UpperLower uplo, blas::Transpose trans,
|
3548: Stream &Stream::ThenBlasTrmv(blas::UpperLower uplo, blas::Transpose trans,
|
3562: Stream &Stream::ThenBlasTrmv(blas::UpperLower uplo, blas::Transpose trans,
|
3577: Stream &Stream::ThenBlasTrmv(blas::UpperLower uplo, blas::Transpose trans,
|
3592: Stream &Stream::ThenBlasTrsv(blas::UpperLower uplo, blas::Transpose trans,
|
3606: Stream &Stream::ThenBlasTrsv(blas::UpperLower uplo, blas::Transpose trans,
|
3620: Stream &Stream::ThenBlasTrsv(blas::UpperLower uplo, blas::Transpose trans,
|
3635: Stream &Stream::ThenBlasTrsv(blas::UpperLower uplo, blas::Transpose trans,
|
3650: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3668: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3684: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3700: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3721: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3749: Stream &operator()(Stream *stream,
|
3751: Stream *, Args..., blas::ProfileResult *),
|
3760: Stream &Stream::ThenBlasGemvWithProfiling(
|
3777: Stream &Stream::ThenBlasGemvWithProfiling(
|
3795: Stream &Stream::ThenBlasGemvWithProfiling(
|
3815: Stream &Stream::ThenBlasGemvWithProfiling(
|
3835: Stream &Stream::ThenBlasGemmWithProfiling(
|
3855: Stream &Stream::ThenBlasGemmWithProfiling(
|
3874: Stream &Stream::ThenBlasGemmWithProfiling(
|
3894: Stream &Stream::ThenBlasGemmWithProfiling(
|
3916: Stream &Stream::ThenBlasGemmWithProfiling(
|
3938: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3963: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3986: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
4009: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
4033: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
4061: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
4089: Stream &Stream::ThenBlasHemm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
4109: Stream &Stream::ThenBlasHemm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
4129: Stream &Stream::ThenBlasHerk(blas::UpperLower uplo, blas::Transpose trans,
|
4144: Stream &Stream::ThenBlasHerk(blas::UpperLower uplo, blas::Transpose trans,
|
4159: Stream &Stream::ThenBlasHer2k(blas::UpperLower uplo, blas::Transpose trans,
|
4178: Stream &Stream::ThenBlasHer2k(blas::UpperLower uplo, blas::Transpose trans,
|
4197: Stream &Stream::ThenBlasSymm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
4213: Stream &Stream::ThenBlasSymm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
4229: Stream &Stream::ThenBlasSymm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
4249: Stream &Stream::ThenBlasSymm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
4269: Stream &Stream::ThenBlasSyrk(blas::UpperLower uplo, blas::Transpose trans,
|
4283: Stream &Stream::ThenBlasSyrk(blas::UpperLower uplo, blas::Transpose trans,
|
4297: Stream &Stream::ThenBlasSyrk(blas::UpperLower uplo, blas::Transpose trans,
|
4313: Stream &Stream::ThenBlasSyrk(blas::UpperLower uplo, blas::Transpose trans,
|
4329: Stream &Stream::ThenBlasSyr2k(blas::UpperLower uplo, blas::Transpose trans,
|
4345: Stream &Stream::ThenBlasSyr2k(blas::UpperLower uplo, blas::Transpose trans,
|
4361: Stream &Stream::ThenBlasSyr2k(blas::UpperLower uplo, blas::Transpose trans,
|
4381: Stream &Stream::ThenBlasSyr2k(blas::UpperLower uplo, blas::Transpose trans,
|
4401: Stream &Stream::ThenBlasTrmm(blas::Side side, blas::UpperLower uplo,
|
4416: Stream &Stream::ThenBlasTrmm(blas::Side side, blas::UpperLower uplo,
|
4431: Stream &Stream::ThenBlasTrmm(blas::Side side, blas::UpperLower uplo,
|
4448: Stream &Stream::ThenBlasTrmm(blas::Side side, blas::UpperLower uplo,
|
4465: Stream &Stream::ThenBlasTrsm(blas::Side side, blas::UpperLower uplo,
|
4480: Stream &Stream::ThenBlasTrsm(blas::Side side, blas::UpperLower uplo,
|
4495: Stream &Stream::ThenBlasTrsm(blas::Side side, blas::UpperLower uplo,
|
4512: Stream &Stream::ThenBlasTrsm(blas::Side side, blas::UpperLower uplo,
|
4529: Stream &Stream::ThenBlasGemmBatched(
|
4541: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4563: Stream &Stream::ThenBlasGemmBatched(
|
4574: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4595: Stream &Stream::ThenBlasGemmBatched(
|
4606: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4627: Stream &Stream::ThenBlasGemmBatched(
|
4640: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4666: Stream &Stream::ThenBlasGemmBatched(
|
4679: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4705: Stream &Stream::ThenBlasGemmStridedBatched(
|
4726: Stream &Stream::ThenBlasGemmStridedBatched(
|
4747: Stream &Stream::ThenBlasGemmStridedBatched(
|
4768: Stream &Stream::ThenBlasGemmStridedBatched(
|
4791: Stream &Stream::ThenBlasGemmStridedBatched(
|
4814: Stream &Stream::ThenSetRngSeed(const uint8 *seed, uint64 seed_bytes) {
|
4832: Stream &Stream::ThenPopulateRandUniform(DeviceMemory<float> *values) {
|
4848: Stream &Stream::ThenPopulateRandGaussian(float mean, float sd,
|
4865: Stream &Stream::ThenPopulateRandGaussian(double mean, double sd,
|
4882: Stream &Stream::ThenPopulateRandUniform(DeviceMemory<double> *values) {
|
4898: Stream &Stream::ThenPopulateRandUniform(
|
4915: Stream &Stream::ThenPopulateRandUniform(
|
4932: Stream &Stream::ThenMemcpy(void *host_dst, const DeviceMemoryBase &gpu_src,
|
4945: Stream &Stream::ThenMemcpy(DeviceMemoryBase *gpu_dst, const void *host_src,
|
4958: Stream &Stream::ThenMemcpy(DeviceMemoryBase *gpu_dst,
|
4971: Stream &Stream::ThenMemZero(DeviceMemoryBase *location, uint64 size) {
|
4983: Stream &Stream::ThenMemset32(DeviceMemoryBase *location, uint32 pattern,
|
4997: Stream &Stream::ThenRnnForward(
|
5034: Stream &Stream::ThenRnnForward(
|
5070: Stream &Stream::ThenRnnForward(
|
5107: Stream &Stream::ThenRnnBackward(
|
5154: Stream &Stream::ThenRnnBackward(
|
5200: Stream &Stream::ThenRnnBackward(
|
5247: Stream &Stream::ThenCtcLoss(const dnn::RnnStateTensorDescriptor &probs_desc,
|
5282: Stream &Stream::ThenTransformTensor(const dnn::BatchDescriptor &input_desc,
|
5303: Stream &Stream::ThenDoHostCallback(std::function<void()> callback) {
|
5314: Stream &Stream::ThenDoHostCallbackWithStatus(
|
5326: Stream &Stream::ThenRunAfterNextBlockHostUntilDone(
|
5340: Stream &Stream::ThenFft(fft::Plan *plan,
|
5358: Stream &Stream::ThenFft(fft::Plan *plan,
|
5376: Stream &Stream::ThenFft(fft::Plan *plan, const DeviceMemory<float> &input,
|
5393: Stream &Stream::ThenFft(fft::Plan *plan, const DeviceMemory<double> &input,
|
5410: Stream &Stream::ThenFft(fft::Plan *plan,
|
5428: Stream &Stream::ThenFft(fft::Plan *plan,
|
5448: Stream &Stream::ThenEnqueueOnBackgroundThread(
|
5460: port::Status Stream::BlockHostUntilDone() {
|
5480: void Stream::RunAfterBlockHostUntilDoneCallbacks() {
|
5497: void Stream::CheckStatus(port::Status status) {
|
260: internal::StreamInterface *implementation)
|
282: parent_->DeallocateStream(this);
|
305: if (parent_->AllocateStream(this)) {
|
899: << "attempting to perform DNN operation using StreamExecutor "
|
929: << "attempting to perform DNN operation using StreamExecutor "
|
1380: << "attempting to perform DNN operation using StreamExecutor "
|
1477: << "attempting to perform DNN operation using StreamExecutor "
|
1901: // The stream is reusable and not ok. Streams have a monotonic state
|
1952: // The returned stream is not ok. Streams have a monotonic state
|
2056: << "attempting to perform BLAS operation using StreamExecutor "
|
4841: << " attempting to perform RNG operation using StreamExecutor"
|
4858: << " attempting to perform RNG operation using StreamExecutor"
|
4875: << " attempting to perform RNG operation using StreamExecutor"
|
4891: << " attempting to perform RNG operation using StreamExecutor"
|
4908: << " attempting to perform RNG operation using StreamExecutor"
|
4925: << " attempting to perform RNG operation using StreamExecutor"
|
5351: << " attempting to perform FFT operation using StreamExecutor"
|
5369: << " attempting to perform FFT operation using StreamExecutor"
|
5386: << " attempting to perform FFT operation using StreamExecutor"
|
5403: << " attempting to perform FFT operation using StreamExecutor"
|
5421: << " attempting to perform FFT operation using StreamExecutor"
|
5439: << " attempting to perform FFT operation using StreamExecutor"
|
5449: std::function<void(StreamExecutor *)> task) {
|
5452: StreamExecutor *stream_executor = this->parent_;
|
215: std::string str = absl::StrCat(stream->DebugStreamPointers(),
|
252: implementation_(parent->implementation()->GetStreamImplementation()),
|
1895: VLOG(1) << DebugStreamPointers() << " reusing sub_stream "
|
1896: << sub_stream->DebugStreamPointers();
|
1910: VLOG(1) << DebugStreamPointers() << " dropped !ok sub_stream "
|
1911: << sub_stream->DebugStreamPointers();
|
1926: VLOG(1) << DebugStreamPointers() << " created new sub_stream "
|
1927: << sub_stream->DebugStreamPointers();
|
1948: VLOG(1) << DebugStreamPointers() << " returned ok sub_stream "
|
1949: << sub_stream->DebugStreamPointers();
|
1955: VLOG(1) << DebugStreamPointers() << " returned !ok sub_stream "
|
1956: << sub_stream->DebugStreamPointers();
|
1967: LOG(FATAL) << DebugStreamPointers()
|
1969: << sub_stream->DebugStreamPointers();
|
1978: LOG(INFO) << DebugStreamPointers()
|
1990: LOG(INFO) << DebugStreamPointers()
|
2001: CheckError(parent_->CreateStreamDependency(this, other));
|
2004: LOG(INFO) << DebugStreamPointers() << " did not wait for "
|
2005: << other->DebugStreamPointers();
|
2022: LOG(INFO) << DebugStreamPointers() << " did not wait for an event.";
|
4822: LOG(INFO) << DebugStreamPointers() << " unable to initialize RNG";
|
4825: LOG(INFO) << DebugStreamPointers()
|
4840: LOG(INFO) << DebugStreamPointers()
|
4857: LOG(INFO) << DebugStreamPointers()
|
4874: LOG(INFO) << DebugStreamPointers()
|
4890: LOG(INFO) << DebugStreamPointers()
|
4907: LOG(INFO) << DebugStreamPointers()
|
4924: LOG(INFO) << DebugStreamPointers()
|
4939: LOG(INFO) << DebugStreamPointers()
|
4952: LOG(INFO) << DebugStreamPointers()
|
4965: LOG(INFO) << DebugStreamPointers()
|
4977: LOG(INFO) << DebugStreamPointers()
|
4990: LOG(INFO) << DebugStreamPointers()
|
5307: LOG(INFO) << DebugStreamPointers()
|
5319: LOG(INFO) << DebugStreamPointers()
|
5331: LOG(INFO) << DebugStreamPointers()
|
5350: LOG(INFO) << DebugStreamPointers()
|
5368: LOG(INFO) << DebugStreamPointers()
|
5385: LOG(INFO) << DebugStreamPointers()
|
5402: LOG(INFO) << DebugStreamPointers()
|
5420: LOG(INFO) << DebugStreamPointers()
|
5438: LOG(INFO) << DebugStreamPointers()
|
5467: LOG(INFO) << DebugStreamPointers() << " " << status;
|
github.com/google/highwayhash:highwayhash/vector256.h: [ master, ] |
---|
671: HH_INLINE void Stream(const V256<T>& v, T* const HH_RESTRICT to) {
|
674: HH_INLINE void Stream(const V256<float>& v, float* const HH_RESTRICT to) {
|
677: HH_INLINE void Stream(const V256<double>& v, double* const HH_RESTRICT to) {
|
github.com/tensorflow/deepmath:tensorflow/tensorflow/stream_executor/stream.cc: [ master, ] |
---|
249: Stream::Stream(StreamExecutor *parent)
|
258: Stream::Stream(StreamExecutor *parent,
|
268: Stream::~Stream() {
|
1738: Stream *Stream::GetOrCreateSubStream() {
|
1785: void Stream::ReturnSubStream(Stream *sub_stream) {
|
5277: string Stream::DebugStreamPointers() const {
|
207: // there are on Stream and how many parameters they each have.
|
208: string CallStr(const char *function_name, Stream *stream,
|
215: " Called Stream::", function_name, "(");
|
284: port::Status Stream::RefreshStatus() {
|
290: Stream &Stream::Init() {
|
309: Stream &Stream::InitTimer(Timer *timer) {
|
320: Stream &Stream::InitWithTimer(Timer *timer) {
|
326: Stream &Stream::ThenRecordEvent(Event *event) {
|
339: Stream &Stream::ThenBatchNormalizationForward(
|
367: Stream &Stream::ThenBatchNormalizationBackward(
|
389: Stream &Stream::ThenBatchNormalizationForward(
|
417: Stream &Stream::ThenBatchNormalizationBackward(
|
440: Stream &Stream::ThenFusedConvolveWithAlgorithm(
|
478: Stream &Stream::ThenFusedConvolveWithAlgorithm(
|
516: Stream &Stream::ThenFusedConvolveWithAlgorithm(
|
555: Stream &Stream::ThenFusedConvolveWithAlgorithm(
|
593: Stream &Stream::ThenConvolveWithAlgorithm(
|
635: Stream &Stream::ThenConvolveWithAlgorithm(
|
677: Stream &Stream::ThenConvolveWithAlgorithm(
|
719: Stream &Stream::ThenConvolve(
|
734: Stream &Stream::ThenConvolveQuantized(
|
764: Stream &Stream::ThenConvolveQuantized(
|
794: Stream &Stream::ThenSeparableConvolve(
|
821: Stream &Stream::ThenConvolveBackwardDataWithAlgorithm(
|
866: Stream &Stream::ThenConvolveBackwardDataWithAlgorithm(
|
911: Stream &Stream::ThenConvolveBackwardDataWithAlgorithm(
|
956: Stream &Stream::ThenConvolveBackwardFilterWithAlgorithm(
|
1001: Stream &Stream::ThenConvolveBackwardFilterWithAlgorithm(
|
1046: Stream &Stream::ThenConvolveBackwardFilterWithAlgorithm(
|
1092: Stream &Stream::ThenConvolveBackwardBiasImpl(
|
1112: Stream &Stream::ThenConvolveBackwardBias(
|
1121: Stream &Stream::ThenConvolveBackwardBias(
|
1130: Stream &Stream::ThenConvolveBackwardBias(
|
1139: Stream &Stream::ThenMatMul(const DeviceMemory<float> &input_data,
|
1158: Stream &Stream::ThenMatMulQuantized(
|
1180: Stream &Stream::ThenMatMulQuantized(
|
1202: Stream &Stream::ThenBiasAdd(const DeviceMemory<float> &input_data,
|
1220: Stream &Stream::ThenPoolForward(
|
1245: Stream &Stream::ThenPoolForward(
|
1267: Stream &Stream::ThenPoolForward(
|
1290: Stream &Stream::ThenPoolForward(
|
1312: Stream &Stream::ThenPoolBackward(
|
1342: Stream &Stream::ThenPoolBackward(
|
1369: Stream &Stream::ThenPoolBackward(
|
1396: Stream &Stream::ThenNormalizeWithDimensions(
|
1414: Stream &Stream::ThenNormalizeBackwardWithDimensions(
|
1438: Stream &Stream::ThenActivate(dnn::ActivationMode activation_mode,
|
1446: Stream &Stream::ThenActivateWithOptions(dnn::ActivationMode activation_mode,
|
1465: Stream &Stream::ThenDepthConcatenate(
|
1495: Stream &Stream::ThenSpaceConcatenate(
|
1542: Stream &Stream::ThenReshape(const dnn::BatchDescriptor &input_dimensions,
|
1560: Stream &Stream::ThenDepthToSpace(
|
1581: Stream &Stream::ThenSpaceToDepth(
|
1602: Stream &Stream::ThenElementwiseOperate(
|
1623: Stream &Stream::ThenElementwiseOperateScaledQuantized(
|
1646: Stream &Stream::ThenXYPad(const dnn::BatchDescriptor &dimensions,
|
1665: Stream &Stream::ThenXYSlice(const dnn::BatchDescriptor &dimensions,
|
1686: Stream &Stream::ThenXYBroadcast(const dnn::BatchDescriptor &dimensions,
|
1704: Stream &Stream::ThenMemcpyD2HQuantized(
|
1721: Stream &Stream::ThenMemcpyH2DQuantized(
|
1744: std::pair<std::unique_ptr<Stream>, bool> &pair = sub_streams_[index];
|
1747: Stream *sub_stream = pair.first.get();
|
1772: sub_streams_.emplace_back(std::unique_ptr<Stream>{new Stream{parent_}},
|
1774: Stream *sub_stream = sub_streams_.back().first.get();
|
1790: std::pair<std::unique_ptr<Stream>, bool> &pair = sub_streams_[index];
|
1820: Stream &Stream::ThenStartTimer(Timer *t) {
|
1832: Stream &Stream::ThenStopTimer(Timer *t) {
|
1844: Stream &Stream::ThenWaitFor(Stream *other) {
|
1858: Stream &Stream::ThenWaitFor(Event *event) {
|
1880: // arguments except the first one of Stream* type.
|
1881: Stream &operator()(Stream *stream,
|
1882: bool (blas::BlasSupport::*blas_func)(Stream *, Args...),
|
1889: Stream &Run(Stream *stream,
|
1890: bool (blas::BlasSupport::*blas_func)(Stream *, Args...),
|
1895: Stream &ThenBlasImpl<Args...>::Run(
|
1896: Stream *stream, bool (blas::BlasSupport::*blas_func)(Stream *, Args...),
|
1915: Stream &Stream::ThenBlasAsum(uint64 elem_count, const DeviceMemory<float> &x,
|
1925: Stream &Stream::ThenBlasAsum(uint64 elem_count, const DeviceMemory<double> &x,
|
1935: Stream &Stream::ThenBlasAsum(uint64 elem_count,
|
1946: Stream &Stream::ThenBlasAsum(uint64 elem_count,
|
1957: Stream &Stream::ThenBlasAxpy(uint64 elem_count, float alpha,
|
1969: Stream &Stream::ThenBlasAxpy(uint64 elem_count, double alpha,
|
1981: Stream &Stream::ThenBlasAxpy(uint64 elem_count, std::complex<float> alpha,
|
1995: Stream &Stream::ThenBlasAxpy(uint64 elem_count, std::complex<double> alpha,
|
2009: Stream &Stream::ThenBlasCopy(uint64 elem_count, const DeviceMemory<float> &x,
|
2019: Stream &Stream::ThenBlasCopy(uint64 elem_count, const DeviceMemory<double> &x,
|
2029: Stream &Stream::ThenBlasCopy(uint64 elem_count,
|
2041: Stream &Stream::ThenBlasCopy(uint64 elem_count,
|
2053: Stream &Stream::ThenBlasDot(uint64 elem_count, const DeviceMemory<float> &x,
|
2065: Stream &Stream::ThenBlasDot(uint64 elem_count, const DeviceMemory<double> &x,
|
2077: Stream &Stream::ThenBlasDotc(uint64 elem_count,
|
2093: Stream &Stream::ThenBlasDotc(uint64 elem_count,
|
2109: Stream &Stream::ThenBlasDotu(uint64 elem_count,
|
2125: Stream &Stream::ThenBlasDotu(uint64 elem_count,
|
2141: Stream &Stream::ThenBlasNrm2(uint64 elem_count, const DeviceMemory<float> &x,
|
2151: Stream &Stream::ThenBlasNrm2(uint64 elem_count, const DeviceMemory<double> &x,
|
2161: Stream &Stream::ThenBlasNrm2(uint64 elem_count,
|
2172: Stream &Stream::ThenBlasNrm2(uint64 elem_count,
|
2183: Stream &Stream::ThenBlasRot(uint64 elem_count, DeviceMemory<float> *x, int incx,
|
2195: Stream &Stream::ThenBlasRot(uint64 elem_count, DeviceMemory<double> *x,
|
2207: Stream &Stream::ThenBlasRot(uint64 elem_count,
|
2220: Stream &Stream::ThenBlasRot(uint64 elem_count,
|
2233: Stream &Stream::ThenBlasRotg(DeviceMemory<float> *a, DeviceMemory<float> *b,
|
2242: Stream &Stream::ThenBlasRotg(DeviceMemory<double> *a, DeviceMemory<double> *b,
|
2251: Stream &Stream::ThenBlasRotg(DeviceMemory<std::complex<float>> *a,
|
2263: Stream &Stream::ThenBlasRotg(DeviceMemory<std::complex<double>> *a,
|
2275: Stream &Stream::ThenBlasRotm(uint64 elem_count, DeviceMemory<float> *x,
|
2287: Stream &Stream::ThenBlasRotm(uint64 elem_count, DeviceMemory<double> *x,
|
2299: Stream &Stream::ThenBlasRotmg(DeviceMemory<float> *d1, DeviceMemory<float> *d2,
|
2311: Stream &Stream::ThenBlasRotmg(DeviceMemory<double> *d1,
|
2324: Stream &Stream::ThenBlasScal(uint64 elem_count, float alpha,
|
2332: Stream &Stream::ThenBlasScal(uint64 elem_count, double alpha,
|
2340: Stream &Stream::ThenBlasScal(uint64 elem_count, float alpha,
|
2348: Stream &Stream::ThenBlasScal(uint64 elem_count, double alpha,
|
2356: Stream &Stream::ThenBlasScal(uint64 elem_count, std::complex<float> alpha,
|
2365: Stream &Stream::ThenBlasScal(uint64 elem_count, std::complex<double> alpha,
|
2374: Stream &Stream::ThenBlasSwap(uint64 elem_count, DeviceMemory<float> *x,
|
2384: Stream &Stream::ThenBlasSwap(uint64 elem_count, DeviceMemory<double> *x,
|
2394: Stream &Stream::ThenBlasSwap(uint64 elem_count,
|
2405: Stream &Stream::ThenBlasSwap(uint64 elem_count,
|
2416: Stream &Stream::ThenBlasIamax(uint64 elem_count, const DeviceMemory<float> &x,
|
2426: Stream &Stream::ThenBlasIamax(uint64 elem_count, const DeviceMemory<double> &x,
|
2436: Stream &Stream::ThenBlasIamax(uint64 elem_count,
|
2447: Stream &Stream::ThenBlasIamax(uint64 elem_count,
|
2458: Stream &Stream::ThenBlasIamin(uint64 elem_count, const DeviceMemory<float> &x,
|
2468: Stream &Stream::ThenBlasIamin(uint64 elem_count, const DeviceMemory<double> &x,
|
2478: Stream &Stream::ThenBlasIamin(uint64 elem_count,
|
2489: Stream &Stream::ThenBlasIamin(uint64 elem_count,
|
2500: Stream &Stream::ThenBlasGbmv(blas::Transpose trans, uint64 m, uint64 n,
|
2516: Stream &Stream::ThenBlasGbmv(blas::Transpose trans, uint64 m, uint64 n,
|
2532: Stream &Stream::ThenBlasGbmv(blas::Transpose trans, uint64 m, uint64 n,
|
2552: Stream &Stream::ThenBlasGbmv(blas::Transpose trans, uint64 m, uint64 n,
|
2572: Stream &Stream::ThenBlasGemv(blas::Transpose trans, uint64 m, uint64 n,
|
2587: Stream &Stream::ThenBlasGemv(blas::Transpose trans, uint64 m, uint64 n,
|
2602: Stream &Stream::ThenBlasGemv(blas::Transpose trans, uint64 m, uint64 n,
|
2622: Stream &Stream::ThenBlasGemv(blas::Transpose trans, uint64 m, uint64 n,
|
2642: Stream &Stream::ThenBlasGer(uint64 m, uint64 n, float alpha,
|
2656: Stream &Stream::ThenBlasGer(uint64 m, uint64 n, double alpha,
|
2670: Stream &Stream::ThenBlasGerc(uint64 m, uint64 n, std::complex<float> alpha,
|
2687: Stream &Stream::ThenBlasGerc(uint64 m, uint64 n, std::complex<double> alpha,
|
2704: Stream &Stream::ThenBlasGeru(uint64 m, uint64 n, std::complex<float> alpha,
|
2721: Stream &Stream::ThenBlasGeru(uint64 m, uint64 n, std::complex<double> alpha,
|
2738: Stream &Stream::ThenBlasHbmv(blas::UpperLower uplo, uint64 n, uint64 k,
|
2757: Stream &Stream::ThenBlasHbmv(blas::UpperLower uplo, uint64 n, uint64 k,
|
2776: Stream &Stream::ThenBlasHemv(blas::UpperLower uplo, uint64 n,
|
2795: Stream &Stream::ThenBlasHemv(blas::UpperLower uplo, uint64 n,
|
2814: Stream &Stream::ThenBlasHer(blas::UpperLower uplo, uint64 n, float alpha,
|
2828: Stream &Stream::ThenBlasHer(blas::UpperLower uplo, uint64 n, double alpha,
|
2842: Stream &Stream::ThenBlasHer2(blas::UpperLower uplo, uint64 n,
|
2860: Stream &Stream::ThenBlasHer2(blas::UpperLower uplo, uint64 n,
|
2878: Stream &Stream::ThenBlasHpmv(blas::UpperLower uplo, uint64 n,
|
2896: Stream &Stream::ThenBlasHpmv(blas::UpperLower uplo, uint64 n,
|
2914: Stream &Stream::ThenBlasHpr(blas::UpperLower uplo, uint64 n, float alpha,
|
2926: Stream &Stream::ThenBlasHpr(blas::UpperLower uplo, uint64 n, double alpha,
|
2938: Stream &Stream::ThenBlasHpr2(blas::UpperLower uplo, uint64 n,
|
2955: Stream &Stream::ThenBlasHpr2(blas::UpperLower uplo, uint64 n,
|
2972: Stream &Stream::ThenBlasSbmv(blas::UpperLower uplo, uint64 n, uint64 k,
|
2986: Stream &Stream::ThenBlasSbmv(blas::UpperLower uplo, uint64 n, uint64 k,
|
3000: Stream &Stream::ThenBlasSpmv(blas::UpperLower uplo, uint64 n, float alpha,
|
3014: Stream &Stream::ThenBlasSpmv(blas::UpperLower uplo, uint64 n, double alpha,
|
3028: Stream &Stream::ThenBlasSpr(blas::UpperLower uplo, uint64 n, float alpha,
|
3039: Stream &Stream::ThenBlasSpr(blas::UpperLower uplo, uint64 n, double alpha,
|
3050: Stream &Stream::ThenBlasSpr2(blas::UpperLower uplo, uint64 n, float alpha,
|
3064: Stream &Stream::ThenBlasSpr2(blas::UpperLower uplo, uint64 n, double alpha,
|
3078: Stream &Stream::ThenBlasSymv(blas::UpperLower uplo, uint64 n, float alpha,
|
3092: Stream &Stream::ThenBlasSymv(blas::UpperLower uplo, uint64 n, double alpha,
|
3106: Stream &Stream::ThenBlasSyr(blas::UpperLower uplo, uint64 n, float alpha,
|
3118: Stream &Stream::ThenBlasSyr(blas::UpperLower uplo, uint64 n, double alpha,
|
3130: Stream &Stream::ThenBlasSyr2(blas::UpperLower uplo, uint64 n, float alpha,
|
3144: Stream &Stream::ThenBlasSyr2(blas::UpperLower uplo, uint64 n, double alpha,
|
3158: Stream &Stream::ThenBlasTbmv(blas::UpperLower uplo, blas::Transpose trans,
|
3172: Stream &Stream::ThenBlasTbmv(blas::UpperLower uplo, blas::Transpose trans,
|
3186: Stream &Stream::ThenBlasTbmv(blas::UpperLower uplo, blas::Transpose trans,
|
3201: Stream &Stream::ThenBlasTbmv(blas::UpperLower uplo, blas::Transpose trans,
|
3216: Stream &Stream::ThenBlasTbsv(blas::UpperLower uplo, blas::Transpose trans,
|
3230: Stream &Stream::ThenBlasTbsv(blas::UpperLower uplo, blas::Transpose trans,
|
3244: Stream &Stream::ThenBlasTbsv(blas::UpperLower uplo, blas::Transpose trans,
|
3259: Stream &Stream::ThenBlasTbsv(blas::UpperLower uplo, blas::Transpose trans,
|
3274: Stream &Stream::ThenBlasTpmv(blas::UpperLower uplo, blas::Transpose trans,
|
3287: Stream &Stream::ThenBlasTpmv(blas::UpperLower uplo, blas::Transpose trans,
|
3300: Stream &Stream::ThenBlasTpmv(blas::UpperLower uplo, blas::Transpose trans,
|
3314: Stream &Stream::ThenBlasTpmv(blas::UpperLower uplo, blas::Transpose trans,
|
3328: Stream &Stream::ThenBlasTpsv(blas::UpperLower uplo, blas::Transpose trans,
|
3341: Stream &Stream::ThenBlasTpsv(blas::UpperLower uplo, blas::Transpose trans,
|
3354: Stream &Stream::ThenBlasTpsv(blas::UpperLower uplo, blas::Transpose trans,
|
3368: Stream &Stream::ThenBlasTpsv(blas::UpperLower uplo, blas::Transpose trans,
|
3382: Stream &Stream::ThenBlasTrmv(blas::UpperLower uplo, blas::Transpose trans,
|
3396: Stream &Stream::ThenBlasTrmv(blas::UpperLower uplo, blas::Transpose trans,
|
3410: Stream &Stream::ThenBlasTrmv(blas::UpperLower uplo, blas::Transpose trans,
|
3425: Stream &Stream::ThenBlasTrmv(blas::UpperLower uplo, blas::Transpose trans,
|
3440: Stream &Stream::ThenBlasTrsv(blas::UpperLower uplo, blas::Transpose trans,
|
3454: Stream &Stream::ThenBlasTrsv(blas::UpperLower uplo, blas::Transpose trans,
|
3468: Stream &Stream::ThenBlasTrsv(blas::UpperLower uplo, blas::Transpose trans,
|
3483: Stream &Stream::ThenBlasTrsv(blas::UpperLower uplo, blas::Transpose trans,
|
3498: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3516: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3532: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3548: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3569: Stream &Stream::ThenBlasGemm(blas::Transpose transa, blas::Transpose transb,
|
3597: Stream &operator()(Stream *stream,
|
3599: Stream *, Args..., blas::ProfileResult *),
|
3608: Stream &Stream::ThenBlasGemvWithProfiling(
|
3625: Stream &Stream::ThenBlasGemvWithProfiling(
|
3643: Stream &Stream::ThenBlasGemvWithProfiling(
|
3663: Stream &Stream::ThenBlasGemvWithProfiling(
|
3683: Stream &Stream::ThenBlasGemmWithProfiling(
|
3703: Stream &Stream::ThenBlasGemmWithProfiling(
|
3722: Stream &Stream::ThenBlasGemmWithProfiling(
|
3742: Stream &Stream::ThenBlasGemmWithProfiling(
|
3764: Stream &Stream::ThenBlasGemmWithProfiling(
|
3786: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3811: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3834: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3857: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3881: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3909: Stream &Stream::ThenBlasGemmWithAlgorithm(
|
3937: Stream &Stream::ThenBlasHemm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
3957: Stream &Stream::ThenBlasHemm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
3977: Stream &Stream::ThenBlasHerk(blas::UpperLower uplo, blas::Transpose trans,
|
3992: Stream &Stream::ThenBlasHerk(blas::UpperLower uplo, blas::Transpose trans,
|
4007: Stream &Stream::ThenBlasHer2k(blas::UpperLower uplo, blas::Transpose trans,
|
4026: Stream &Stream::ThenBlasHer2k(blas::UpperLower uplo, blas::Transpose trans,
|
4045: Stream &Stream::ThenBlasSymm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
4061: Stream &Stream::ThenBlasSymm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
4077: Stream &Stream::ThenBlasSymm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
4097: Stream &Stream::ThenBlasSymm(blas::Side side, blas::UpperLower uplo, uint64 m,
|
4117: Stream &Stream::ThenBlasSyrk(blas::UpperLower uplo, blas::Transpose trans,
|
4131: Stream &Stream::ThenBlasSyrk(blas::UpperLower uplo, blas::Transpose trans,
|
4145: Stream &Stream::ThenBlasSyrk(blas::UpperLower uplo, blas::Transpose trans,
|
4161: Stream &Stream::ThenBlasSyrk(blas::UpperLower uplo, blas::Transpose trans,
|
4177: Stream &Stream::ThenBlasSyr2k(blas::UpperLower uplo, blas::Transpose trans,
|
4193: Stream &Stream::ThenBlasSyr2k(blas::UpperLower uplo, blas::Transpose trans,
|
4209: Stream &Stream::ThenBlasSyr2k(blas::UpperLower uplo, blas::Transpose trans,
|
4229: Stream &Stream::ThenBlasSyr2k(blas::UpperLower uplo, blas::Transpose trans,
|
4249: Stream &Stream::ThenBlasTrmm(blas::Side side, blas::UpperLower uplo,
|
4264: Stream &Stream::ThenBlasTrmm(blas::Side side, blas::UpperLower uplo,
|
4279: Stream &Stream::ThenBlasTrmm(blas::Side side, blas::UpperLower uplo,
|
4296: Stream &Stream::ThenBlasTrmm(blas::Side side, blas::UpperLower uplo,
|
4313: Stream &Stream::ThenBlasTrsm(blas::Side side, blas::UpperLower uplo,
|
4328: Stream &Stream::ThenBlasTrsm(blas::Side side, blas::UpperLower uplo,
|
4343: Stream &Stream::ThenBlasTrsm(blas::Side side, blas::UpperLower uplo,
|
4360: Stream &Stream::ThenBlasTrsm(blas::Side side, blas::UpperLower uplo,
|
4377: Stream &Stream::ThenBlasGemmBatched(
|
4389: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4411: Stream &Stream::ThenBlasGemmBatched(
|
4422: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4443: Stream &Stream::ThenBlasGemmBatched(
|
4454: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4475: Stream &Stream::ThenBlasGemmBatched(
|
4488: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4514: Stream &Stream::ThenBlasGemmBatched(
|
4527: Stream &Stream::ThenBlasGemmBatchedWithScratch(
|
4553: Stream &Stream::ThenBlasGemmStridedBatched(
|
4574: Stream &Stream::ThenBlasGemmStridedBatched(
|
4595: Stream &Stream::ThenBlasGemmStridedBatched(
|
4616: Stream &Stream::ThenBlasGemmStridedBatched(
|
4639: Stream &Stream::ThenBlasGemmStridedBatched(
|
4662: Stream &Stream::ThenSetRngSeed(const uint8 *seed, uint64 seed_bytes) {
|
4680: Stream &Stream::ThenPopulateRandUniform(DeviceMemory<float> *values) {
|
4696: Stream &Stream::ThenPopulateRandGaussian(float mean, float sd,
|
4713: Stream &Stream::ThenPopulateRandGaussian(double mean, double sd,
|
4730: Stream &Stream::ThenPopulateRandUniform(DeviceMemory<double> *values) {
|
4746: Stream &Stream::ThenPopulateRandUniform(
|
4763: Stream &Stream::ThenPopulateRandUniform(
|
4780: Stream &Stream::ThenMemcpy(void *host_dst, const DeviceMemoryBase &gpu_src,
|
4793: Stream &Stream::ThenMemcpy(DeviceMemoryBase *gpu_dst, const void *host_src,
|
4806: Stream &Stream::ThenMemcpy(DeviceMemoryBase *gpu_dst,
|
4819: Stream &Stream::ThenMemZero(DeviceMemoryBase *location, uint64 size) {
|
4831: Stream &Stream::ThenMemset32(DeviceMemoryBase *location, uint32 pattern,
|
4845: Stream &Stream::ThenRnnForward(
|
4882: Stream &Stream::ThenRnnForward(
|
4918: Stream &Stream::ThenRnnForward(
|
4955: Stream &Stream::ThenRnnBackward(
|
5002: Stream &Stream::ThenRnnBackward(
|
5048: Stream &Stream::ThenRnnBackward(
|
5095: Stream &Stream::ThenTransformTensor(const dnn::BatchDescriptor &input_desc,
|
5116: Stream &Stream::ThenDoHostCallback(std::function<void()> callback) {
|
5127: Stream &Stream::ThenDoHostCallbackWithStatus(
|
5139: Stream &Stream::ThenFft(fft::Plan *plan,
|
5157: Stream &Stream::ThenFft(fft::Plan *plan,
|
5175: Stream &Stream::ThenFft(fft::Plan *plan, const DeviceMemory<float> &input,
|
5192: Stream &Stream::ThenFft(fft::Plan *plan, const DeviceMemory<double> &input,
|
5209: Stream &Stream::ThenFft(fft::Plan *plan,
|
5227: Stream &Stream::ThenFft(fft::Plan *plan,
|
5247: Stream &Stream::ThenEnqueueOnBackgroundThread(
|
5259: port::Status Stream::BlockHostUntilDone() {
|
5283: void Stream::CheckStatus(port::Status status) {
|
259: internal::StreamInterface *implementation)
|
280: parent_->DeallocateStream(this);
|
298: if (parent_->AllocateStream(this)) {
|
757: << "attempting to perform DNN operation using StreamExecutor "
|
787: << "attempting to perform DNN operation using StreamExecutor "
|
1238: << "attempting to perform DNN operation using StreamExecutor "
|
1335: << "attempting to perform DNN operation using StreamExecutor "
|
1755: // The stream is reusable and not ok. Streams have a monotonic state
|
1801: // The returned stream is not ok. Streams have a monotonic state
|
1904: << "attempting to perform BLAS operation using StreamExecutor "
|
4689: << " attempting to perform RNG operation using StreamExecutor"
|
4706: << " attempting to perform RNG operation using StreamExecutor"
|
4723: << " attempting to perform RNG operation using StreamExecutor"
|
4739: << " attempting to perform RNG operation using StreamExecutor"
|
4756: << " attempting to perform RNG operation using StreamExecutor"
|
4773: << " attempting to perform RNG operation using StreamExecutor"
|
5150: << " attempting to perform FFT operation using StreamExecutor"
|
5168: << " attempting to perform FFT operation using StreamExecutor"
|
5185: << " attempting to perform FFT operation using StreamExecutor"
|
5202: << " attempting to perform FFT operation using StreamExecutor"
|
5220: << " attempting to perform FFT operation using StreamExecutor"
|
5238: << " attempting to perform FFT operation using StreamExecutor"
|
5248: std::function<void(StreamExecutor *)> task) {
|
5251: StreamExecutor *stream_executor = this->parent_;
|
214: string str = absl::StrCat(stream->DebugStreamPointers(),
|
251: implementation_(parent->implementation()->GetStreamImplementation()),
|
1749: VLOG(1) << DebugStreamPointers() << " reusing sub_stream "
|
1750: << sub_stream->DebugStreamPointers();
|
1763: VLOG(1) << DebugStreamPointers() << " dropped !ok sub_stream "
|
1764: << sub_stream->DebugStreamPointers();
|
1779: VLOG(1) << DebugStreamPointers() << " created new sub_stream "
|
1780: << sub_stream->DebugStreamPointers();
|
1797: VLOG(1) << DebugStreamPointers() << " returned ok sub_stream "
|
1798: << sub_stream->DebugStreamPointers();
|
1804: VLOG(1) << DebugStreamPointers() << " returned !ok sub_stream "
|
1805: << sub_stream->DebugStreamPointers();
|
1815: LOG(FATAL) << DebugStreamPointers()
|
1817: << sub_stream->DebugStreamPointers();
|
1826: LOG(INFO) << DebugStreamPointers()
|
1838: LOG(INFO) << DebugStreamPointers()
|
1849: CheckError(parent_->CreateStreamDependency(this, other));
|
1852: LOG(INFO) << DebugStreamPointers() << " did not wait for "
|
1853: << other->DebugStreamPointers();
|
1870: LOG(INFO) << DebugStreamPointers() << " did not wait for an event.";
|
4670: LOG(INFO) << DebugStreamPointers() << " unable to initialize RNG";
|
4673: LOG(INFO) << DebugStreamPointers()
|
4688: LOG(INFO) << DebugStreamPointers()
|
4705: LOG(INFO) << DebugStreamPointers()
|
4722: LOG(INFO) << DebugStreamPointers()
|
4738: LOG(INFO) << DebugStreamPointers()
|
4755: LOG(INFO) << DebugStreamPointers()
|
4772: LOG(INFO) << DebugStreamPointers()
|
4787: LOG(INFO) << DebugStreamPointers()
|
4800: LOG(INFO) << DebugStreamPointers()
|
4813: LOG(INFO) << DebugStreamPointers()
|
4825: LOG(INFO) << DebugStreamPointers()
|
4838: LOG(INFO) << DebugStreamPointers()
|
5120: LOG(INFO) << DebugStreamPointers()
|
5132: LOG(INFO) << DebugStreamPointers()
|
5149: LOG(INFO) << DebugStreamPointers()
|
5167: LOG(INFO) << DebugStreamPointers()
|
5184: LOG(INFO) << DebugStreamPointers()
|
5201: LOG(INFO) << DebugStreamPointers()
|
5219: LOG(INFO) << DebugStreamPointers()
|
5237: LOG(INFO) << DebugStreamPointers()
|
5266: LOG(INFO) << DebugStreamPointers() << " " << status;
|
github.com/tensorflow/deepmath:fold/tensorflow/tensorflow/stream_executor/stream.cc: [ master, ] |
---|
219: Stream::Stream(StreamExecutor *parent)
|
228: Stream::Stream(StreamExecutor *parent,
|
238: Stream::~Stream() {
|
1442: Stream *Stream::GetOrCreateSubStream() {
|
1459: void Stream::ReturnSubStream(Stream *sub_stream) {
|
178: // there are on Stream and how many parameters they each have.
|
179: string CallStr(const char *function_name, Stream *stream,
|
185: string str = port::StrCat("Called Stream::", function_name, "(");
|
248: Stream &Stream::Init() {
|
267: Stream &Stream::InitTimer(Timer *timer) {
|
278: Stream &Stream::InitWithTimer(Timer *timer) {
|
284: Stream &Stream::ThenRecordEvent(Event *event) {
|
297: Stream &Stream::ThenBatchNormalizationForward(
|
325: Stream &Stream::ThenBatchNormalizationBackward(
|
347: Stream &Stream::ThenConvolveWithScratch(
|
375: Stream &Stream::ThenConvolveWithScratch(
|
402: Stream &Stream::ThenConvolveWithAlgorithm(
|
433: Stream &Stream::ThenConvolveWithAlgorithm(
|
464: Stream &Stream::ThenConvolve(
|
478: Stream &Stream::ThenConvolveQuantized(
|
508: Stream &Stream::ThenConvolveQuantized(
|
538: Stream &Stream::ThenSeparableConvolve(
|
565: Stream &Stream::ThenConvolveBackwardDataWithScratch(
|
593: Stream &Stream::ThenConvolveBackwardDataWithAlgorithm(
|
626: Stream &Stream::ThenConvolveBackwardDataWithAlgorithm(
|
659: Stream &Stream::ThenConvolveBackwardDataWithScratch(
|
687: Stream &Stream::ThenConvolveBackwardData(
|
701: Stream &Stream::ThenConvolveBackwardFilterWithScratch(
|
729: Stream &Stream::ThenConvolveBackwardFilterWithAlgorithm(
|
762: Stream &Stream::ThenConvolveBackwardFilterWithScratch(
|
790: Stream &Stream::ThenConvolveBackwardFilterWithAlgorithm(
|
823: Stream &Stream::ThenConvolveBackwardFilter(
|
838: Stream &Stream::ThenConvolveBackwardBiasImpl(
|
858: Stream &Stream::ThenConvolveBackwardBias(
|
867: Stream &Stream::ThenConvolveBackwardBias(
|
876: Stream &Stream::ThenConvolveBackwardBias(
|
885: Stream &Stream::ThenMatMul(const DeviceMemory<float> &input_data,
|
904: Stream &Stream::ThenMatMulQuantized(
|
926: Stream &Stream::ThenMatMulQuantized(
|
948: Stream &Stream::ThenBiasAdd(const DeviceMemory<float> &input_data,
|
966: Stream &Stream::ThenPoolForward(
|
987: Stream &Stream::ThenPoolForward(
|
1008: Stream &Stream::ThenPoolBackward(
|
1032: Stream &Stream::ThenPoolBackward(
|
1056: Stream &Stream::ThenNormalize(
|
1072: Stream &Stream::ThenNormalizeWithDimensions(
|
1090: Stream &Stream::ThenNormalizeBackwardWithDimensions(
|
1112: Stream &Stream::ThenActivate(dnn::ActivationMode activation_mode,
|
1120: Stream &Stream::ThenActivateWithOptions(dnn::ActivationMode activation_mode,
|
1139: Stream &Stream::ThenDepthConcatenate(
|
1169: Stream &Stream::ThenSpaceConcatenate(
|
1216: Stream &Stream::ThenReshape(const dnn::BatchDescriptor &input_dimensions,
|
1234: Stream &Stream::ThenDepthToSpace(
|
1255: Stream &Stream::ThenSpaceToDepth(
|
1276: Stream &Stream::ThenElementwiseOperate(
|
1297: Stream &Stream::ThenElementwiseOperateScaledQuantized(
|
1320: Stream &Stream::ThenXYPad(const dnn::BatchDescriptor &dimensions,
|
1339: Stream &Stream::ThenXYSlice(const dnn::BatchDescriptor &dimensions,
|
1360: Stream &Stream::ThenXYBroadcast(const dnn::BatchDescriptor &dimensions,
|
1378: Stream &Stream::ThenMemcpyD2HQuantized(
|
1395: Stream &Stream::ThenMemcpyH2DQuantized(
|
1412: Stream &Stream::ThenCopyHostBuffer2Device(
|
1427: Stream &Stream::ThenCopyDevice2HostBuffer(
|
1450: sub_streams_.emplace_back(std::unique_ptr<Stream>{new Stream{parent_}},
|
1452: Stream *sub_stream = sub_streams_.back().first.get();
|
1470: Stream &Stream::ThenStartTimer(Timer *t) {
|
1481: Stream &Stream::ThenStopTimer(Timer *t) {
|
1492: Stream &Stream::ThenWaitFor(Stream *other) {
|
1505: Stream &Stream::ThenWaitFor(Event *event) {
|
1527: // arguments except the first one of Stream* type.
|
1528: Stream &operator()(Stream *stream,
|
1529: bool (blas::BlasSupport::*blas_func)(Stream *, Args...),
|
1536: Stream &Run(Stream *stream,
|
1537: bool (blas::BlasSupport::*blas_func)(Stream *, Args...),
|
1542: Stream &ThenBlasImpl<Args...>::Run(
|
1543: Stream *stream, bool (blas::BlasSupport::*blas_func)(Stream *, Args...),
|
1562: Stream &Stream::ThenBlasAsum(uint64 elem_count, const DeviceMemory<float> &x,
|
1572: Stream &Stream::ThenBlasAsum(uint64 elem_count, const DeviceMemory<double> &x,
|
1582: Stream &Stream::ThenBlasAsum(uint64 elem_count,
|
1593: Stream &Stream::ThenBlasAsum(uint64 elem_count,
|
1604: Stream &Stream::ThenBlasAxpy(uint64 elem_count, float alpha,
|
1616: Stream &Stream::ThenBlasAxpy(uint64 elem_count, double alpha,
|
1628: Stream &Stream::ThenBlasAxpy(uint64 elem_count, std::complex<float> alpha,
|
1642: Stream &Stream::ThenBlasAxpy(uint64 elem_count, std::complex<double> alpha,
|
1656: Stream &Stream::ThenBlasCopy(uint64 elem_count, const DeviceMemory<float> &x,
|
1666: Stream &Stream::ThenBlasCopy(uint64 elem_count, const DeviceMemory<double> &x,
|
1676: Stream &Stream::ThenBlasCopy(uint64 elem_count,
|
1688: Stream &Stream::ThenBlasCopy(uint64 elem_count,
|
1700: Stream &Stream::ThenBlasDot(uint64 elem_count, const DeviceMemory<float> &x,
|
1712: Stream &Stream::ThenBlasDot(uint64 elem_count, const DeviceMemory<double> &x,
|
1724: Stream &Stream::ThenBlasDotc(uint64 elem_count,
|
1740: Stream &Stream::ThenBlasDotc(uint64 elem_count,
|
1756: Stream &Stream::ThenBlasDotu(uint64 elem_count,
|
1772: Stream &Stream::ThenBlasDotu(uint64 elem_count,
|
1788: Stream &Stream::ThenBlasNrm2(uint64 elem_count, const DeviceMemory<float> &x,
|
1798: Stream &Stream::ThenBlasNrm2(uint64 elem_count, const DeviceMemory<double> &x,
|
1808: Stream &Stream::ThenBlasNrm2(uint64 elem_count,
|
1819: Stream &Stream::ThenBlasNrm2(uint64 elem_count,
|
1830: Stream &Stream::ThenBlasRot(uint64 elem_count, DeviceMemory<float> *x, int incx,
|
1842: Stream &Stream::ThenBlasRot(uint64 elem_count, DeviceMemory<double> *x,
|
1854: Stream &Stream::ThenBlasRot(uint64 elem_count,
|
1867: Stream &Stream::ThenBlasRot(uint64 elem_count,
|
1880: Stream &Stream::ThenBlasRotg(DeviceMemory<float> *a, DeviceMemory<float> *b,
|
1889: Stream &Stream::ThenBlasRotg(DeviceMemory<double> *a, DeviceMemory<double> *b,
|
1898: Stream &Stream::ThenBlasRotg(DeviceMemory<std::complex<float>> *a,
|
1910: Stream &Stream::ThenBlasRotg(DeviceMemory<std::complex<double>> *a,
|
1922: Stream &Stream::ThenBlasRotm(uint64 elem_count, DeviceMemory<float> *x,
|
1934: Stream &Stream::ThenBlasRotm(uint64 elem_count, DeviceMemory<double> *x,
|
1946: Stream &Stream::ThenBlasRotmg(DeviceMemory<float> *d1, DeviceMemory<float> *d2,
|
1958: Stream &Stream::ThenBlasRotmg(DeviceMemory<double> *d1,
|
1971: Stream &Stream::ThenBlasScal(uint64 elem_count, float alpha,
|
1979: Stream &Stream::ThenBlasScal(uint64 elem_count, double alpha,
|
1987: Stream &Stream::ThenBlasScal(uint64 elem_count, float alpha,
|
1995: Stream &Stream::ThenBlasScal(uint64 elem_count, double alpha,
|
2003: Stream &Stream::ThenBlasScal(uint64 elem_count, std::complex<float> alpha,
|
|