-
ar.com.fdvs.dj.output.ReportWriter.writeTo()
-
bg.smoc.model.GradeProto.Grade.writeTo()
-
co.cask.tigon.sql.io.GDATEncoder.writeTo()
Writes a GDAT format DATA record to the provided outputStream. This method is to be called after calling all the required write*() methods.
@param outputStream GDAT record is written to this outputStream
@throws IOException
-
com.alibaba.citrus.service.template.TemplateEngine.writeTo()
渲染模板,并将渲染的结果送到字节输出流中。
-
com.alibaba.citrus.service.template.TemplateService.writeTo()
渲染模板,并将渲染的结果送到字节输出流中。
-
com.alibaba.citrus.util.io.ByteArray.writeTo()
-
com.alibaba.dubbo.rpc.protocol.thrift.io.RandomAccessByteArrayOutputStream.writeTo()
-
com.alibaba.fastjson.serializer.SerializeWriter.writeTo()
Writes the contents of the buffer to another character stream.
@param out the output stream to write to
@throws IOException If an I/O error occurs.
-
com.android.dx.dex.code.DalvInsnList.writeTo()
Writes all the instructions in this instance to the given output destination.
@param out {@code non-null;} where to write to
-
com.aphyr.riemann.Proto.Msg.writeTo()
-
com.basho.riak.pbc.RPB.RpbPutReq.writeTo()
-
com.basho.riak.protobuf.RiakKvPB.RpbPutReq.writeTo()
-
com.bergerkiller.bukkit.common.nbt.CommonTagCompound.writeTo()
Writes this CommonTagCompound to the OutputStream specified. This method writes the compound as GZIP-compressed data.
@param stream to write to
@throws IOException
-
com.chenshuo.muduo.protorpc.RpcProto.RpcMessage.writeTo()
-
com.cybozu.vmbkp.util.VmdkBitmap.writeTo()
Write bitmap data to output stream.
-
com.eclipsesource.json.JsonObject.writeTo()
-
com.esri.gpt.control.georss.AtomFeedWriter.AtomEntry.WriteTo()
-
com.eviware.soapui.impl.wsdl.submit.transports.http.support.attachments.MimeMessageMockResponseEntity.writeTo()
-
com.eviware.soapui.impl.wsdl.teststeps.WsdlTestStepResult.writeTo()
-
com.fasterxml.jackson.jaxrs.xml.JacksonXMLProvider.writeTo()
Method that JAX-RS container calls to serialize given value.
-
com.google.api.client.http.HttpContent.writeTo()
Writes the content to the given output stream.
The recommendation for implementations is that they should not close the output stream. Callers should not assume whether or not the output stream has been closed. Implementations that do not close the output stream should flush it at the end of the method.
-
com.google.api.client.http.UrlEncodedContent.writeTo()
-
com.google.api.client.http.json.JsonHttpContent.writeTo()
-
com.google.api.client.http.xml.XmlHttpContent.writeTo()
-
com.google.k2crypto.KeyProto.KeyData.writeTo()
-
com.google.protobuf.ByteString.Output.writeTo()
-
com.google.protobuf.DynamicMessage.writeTo()
-
com.google.protobuf.Message.writeTo()
Serializes the message and writes it to {@code output}. This does not flush or close the stream.
-
com.google.transit.realtime.GtfsRealtime.FeedMessage.writeTo()
-
com.hazelcast.com.eclipsesource.json.JsonObject.writeTo()
-
com.hazelcast.nio.Packet.writeTo()
-
com.hazelcast.nio.serialization.DataAdapter.writeTo()
WARNING: Should be in sync with {@link Data#writeData(com.hazelcast.nio.ObjectDataOutput)}
-
com.itextpdf.text.pdf.ByteBuffer.writeTo()
Writes the complete contents of this byte buffer output to the specified output stream argument, as if by calling the output stream's write method using out.write(buf, 0, count)
.
@param out the output stream to which to write the data.
@exception IOException if an I/O error occurs.
-
com.liferay.faces.util.io.ResourceOutputStream.writeTo()
-
com.linkedin.databus.core.DbusEventInternalReadable.writeTo()
-
com.lowagie.text.pdf.FdfWriter.writeTo()
Writes the content to a stream.
@param os the stream
@throws IOException on error
-
com.mongodb.gridfs.GridFSDBFile.writeTo()
Writes the file's data to a file on disk
@param filename the file name on disk
@return
@throws IOException
-
com.netflix.suro.sink.Sink.writeTo()
Write a single message into the sink
@param message
-
com.netflix.suro.sink.kafka.KafkaSink.writeTo()
-
com.nexirius.util.TextToken.writeTo()
-
com.opengamma.integration.copier.timeseries.reader.SingleSheetMultiTimeSeriesReader.writeTo()
-
com.opengamma.integration.copier.timeseries.reader.TimeSeriesReader.writeTo()
-
com.opensymphony.module.sitemesh.html.CustomTag.writeTo()
-
com.oreilly.servlet.multipart.FilePart.writeTo()
Write this file part to a file or directory. If the user supplied a file, we write it to that file, and if they supplied a directory, we write it to that directory with the filename that accompanied it. If this part doesn't contain a file this method does nothing.
@return number of bytes written
@exception IOException if an input or output exception has occurred.
-
com.rabbitmq.client.impl.Frame.writeTo()
Public API - writes this Frame to the given DataOutputStream
-
com.scooterframework.web.controller.UploadFile.writeTo()
Writes an uploaded item to disk.
@param dirPath The directory into which the uploaded item should be stored.
@throws Exception
-
com.strobel.decompiler.ast.Block.writeTo()
-
com.sun.corba.se.impl.encoding.CDROutputObject.writeTo()
Write the contents of the CDROutputStream to the specified output stream. Has the side-effect of pushing any current Message onto the Message list.
@param s The output stream to write to.
-
com.sun.corba.se.impl.encoding.EncapsOutputStream.writeTo()
-
com.sun.corba.se.impl.encoding.MarshalOutputStream.writeTo()
-
com.sun.enterprise.admin.remote.writer.ProprietaryWriter.writeTo()
-
com.sun.java.util.jar.pack.Package.File.writeTo()
-
com.sun.jersey.spi.template.ResolvedViewable.writeTo()
Write the resolved viewable.
This method defers to {@link ViewProcessor#writeTo(java.lang.Object,com.sun.jersey.api.view.Viewable,java.io.OutputStream) }to write the viewable utilizing the template reference.
@param out the output stream that the view processor writes to.
@throws java.io.IOException
-
com.sun.xml.internal.messaging.saaj.util.ByteOutputStream.writeTo()
-
com.sun.xml.internal.messaging.saaj.util.XMLDeclarationParser.writeTo()
-
com.sun.xml.internal.ws.api.server.SDDocument.writeTo()
Writes the document to the given {@link OutputStream}.
Since {@link ServiceDefinition} doesn't know which endpoint address{@link Adapter} is serving to, (and often it serves multiple URLssimultaneously), this method takes the PortAddressResolver as a parameter, so that it can produce the corret address information in the generated WSDL.
@param portAddressResolver An endpoint address resolver that gives endpoint address for a WSDL port. Can be null.
@param resolver Used to resolve relative references among documents.
@param os The {@link OutputStream} that receives the generated document.
@throws IOException if there was a failure reported from the {@link OutputStream}.
-
com.sun.xml.internal.ws.util.ByteArrayBuffer.writeTo()
-
com.sun.xml.messaging.saaj.util.ByteOutputStream.writeTo()
-
com.sun.xml.messaging.saaj.util.XMLDeclarationParser.writeTo()
-
com.sun.xml.ws.api.message.Message.writeTo()
Writes the whole SOAP message (but not attachments) to the given writer. This consumes the message.
@throws XMLStreamException If the {@link XMLStreamWriter} reports an error,or some other errors happen during the processing.
-
com.sun.xml.ws.api.server.SDDocument.writeTo()
Writes the document to the given {@link OutputStream}.
Since {@link ServiceDefinition} doesn't know which endpoint address{@link Adapter} is serving to, (and often it serves multiple URLssimultaneously), this method takes the PortAddressResolver as a parameter, so that it can produce the corret address information in the generated WSDL.
@param portAddressResolver An endpoint address resolver that gives endpoint address for a WSDL port. Can be null.
@param resolver Used to resolve relative references among documents.
@param os The {@link OutputStream} that receives the generated document.
@throws IOException if there was a failure reported from the {@link OutputStream}.
-
com.sun.xml.ws.security.opt.crypto.JAXBData.writeTo()
-
com.sun.xml.ws.util.ByteArrayBuffer.writeTo()
-
com.trifork.riak.RPB.RpbPutReq.writeTo()
-
com.volantis.mcs.migrate.impl.framework.io.OutputStreamByteArray.writeTo()
Write the contents of the byte array provided during construction to the output stream provided.
@param output the output stream to write the byte array contents to.
@throws IOException if there was an I/O error during the write.
-
com.vtence.molecule.Body.writeTo()
-
com.xmlcalabash.runtime.XPipeline.writeTo()
-
de.fhkn.in.uce.stun.message.Message.writeTo()
Encodes and writes this {@link Message} to the given output stream.
@param out the stream to that this message gets written to
@throws IOException if an I/O error occurs
-
de.iritgo.aktera.comm.BinaryWrapper.writeTo()
Writes the data stored to the supplied output stream. Ready method for writing out to Browsers and other clients as needed.
@param outStream The stream to write to
@return The number of bytes written.
@throws IOException Thrown if an error occurs reading/writing streams.
-
erjang.EBinary.writeTo()
@param barr
@throws IOException
@throws IOException
-
flash.swf.TagEncoder.writeTo()
-
freenet.client.Metadata.writeTo()
Write the metadata as binary.
@throws IOException If an I/O error occurred while writing the data.
@throws MetadataUnresolvedException
-
freenet.support.SimpleFieldSet.writeTo()
Write the contents of the SimpleFieldSet to a Writer. Note: The caller *must* buffer the writer to avoid lousy performance! (StringWriter is by definition buffered, otherwise wrap it in a BufferedWriter)
@warning keep in mind that a Writer is not necessarily UTF-8!!
-
game.Tag.writeTo()
Read a tag and its nested tags from an InputStream.
@param os stream to write to, like a FileOutputStream
@throws IOException if this is not a valid NBT structure or if any IOException occurred.
-
groovy.lang.Writable.writeTo()
Writes this object to the given writer.
This is used to defer content creation until the point when it is streamed to the output destination. Oftentimes, content will be defined but not necessarily created (as is may be the case with a Closure definition.) In that case, the output is then 'deferred' to the point when it is serialized to the writer. This class may be used whenever an object should be responsible for creating its own textual representation, but creating the entire output as a single String would be inefficient (such as outputting a multi-gigabyte XML document.)
@param out the Writer to which this Writable should output its data.
@return the Writer that was passed
@throws IOException if an error occurred while outputting data to the writer
-
hudson.util.CharSpool.writeTo()
-
hudson.util.ListBoxModel.writeTo()
-
iaik.pkcs.PKCS7CertList.writeTo()
-
ie.omk.smpp.message.SMPPPacket.writeTo()
Write the byte representation of this SMPP packet to an OutputStream
@param out The OutputStream to use
@throws java.io.IOException if there's an error writing to the output stream.
-
ign.middleman.helpers.WebResponse.writeTo()
-
io.crate.action.sql.SQLResponse.writeTo()
-
io.crate.blob.PutChunkReplicaRequest.writeTo()
-
io.crate.executor.transport.distributed.DistributedResultRequest.writeTo()
-
io.crate.operation.aggregation.AggregationState.writeTo()
-
io.crate.planner.node.dql.CollectNode.writeTo()
-
io.crate.planner.node.dql.MergeNode.writeTo()
-
it.polito.appeal.traci.protocol.RequestMessage.writeTo()
Writes the commands to the specified {@link DataOutputStream} object, inthe same order as the calls of {@link #append(Command)}.
@param dos
@throws IOException
-
it.polito.appeal.traci.protocol.StringList.writeTo()
-
jade.imtp.leap.JICP.JICPPacket.writeTo()
Writes the packet into the provided OutputStream
. The packet is serialized in an internal representation, so the data should be retrieved and deserialized with the readFrom()
static method below. The output stream is flushed but not opened nor closed by this method.
@param out The OutputStream
to write the data in
@exception May send a large bunch of exceptions, mainly in the IOpackage.
-
jade.imtp.leap.http.HTTPResponse.writeTo()
Method declaration
@see
-
java.io.ByteArrayOutputStream.writeTo()
Take the contents of this stream and write it to the output stream out
.
@param out An OutputStream on which to write the contents of this stream.
@throws IOException If an error occurs when writing to output stream
-
java.io.CharArrayWriter.writeTo()
Writes the contents of this CharArrayWriter to another Writer. The output is all the characters that have been written to the receiver since the last reset or since the creation.
@param out the non-null Writer on which to write the contents.
@throws IOException If an error occurs attempting to write the contents out.
-
javax.activation.DataContentHandler.writeTo()
-
javax.activation.DataHandler.writeTo()
-
javax.mail.BodyPart.writeTo()
-
javax.mail.Message.writeTo()
-
javax.mail.Multipart.writeTo()
Encode and write this multipart to the supplied OutputStream; the encoding used is determined by the implementation.
@param out the stream to write to
@throws IOException
@throws MessagingException
-
javax.mail.Part.writeTo()
-
javax.mail.internet.MimeBodyPart.writeTo()
-
javax.mail.internet.MimeMessage.writeTo()
-
javax.mail.internet.MimeMultipart.writeTo()
-
javax.mail.internet.MimePart.writeTo()
-
javax.ws.rs.ext.MessageBodyWriter.writeTo()
Write a type to an HTTP response. The response header map is mutable but any changes must be made before writing to the output stream since the headers will be flushed prior to writing the response body.
@param t the instance to write.
@param type the class of object that is to be written.
@param genericType the type of object to be written, obtained eitherby reflection of a resource method return type or by inspection of the returned instance. {@link javax.ws.rs.core.GenericEntity}provides a way to specify this information at runtime.
@param annotations an array of the annotations on the resourcemethod that returns the object.
@param mediaType the media type of the HTTP entity.
@param httpHeaders a mutable map of the HTTP response headers.
@param entityStream the {@link OutputStream} for the HTTP entity. Theimplementation should not close the output stream.
@throws java.io.IOException if an IO error arises
@throws javax.ws.rs.WebApplicationException if a specific HTTP error response needs to be produced. Only effective if thrown prior to the response being committed.
-
javax.xml.ws.wsaddressing.W3CEndpointReference.writeTo()
-
muduo.rpc.proto.RpcProto.RpcMessage.writeTo()
-
net.htmlparser.jericho.OutputDocument.writeTo()
Writes the final content of this output document to the specified
Writer
.
The {@link #writeTo(Writer, int begin, int end)} method allows the output of a portion of the output document.
If the output is required in the form of a Reader
, use {@link CharStreamSourceUtil#getReader(CharStreamSource) CharStreamSourceUtil.getReader(this)} instead.
@param writer the destination java.io.Writer
for the output.
@throws IOException if an I/O exception occurs.
@see #toString()
-
net.timewalker.ffmq3.utils.RawDataBuffer.writeTo()
-
net.timewalker.ffmq3.utils.Settings.writeTo()
-
net.yacy.cora.protocol.http.HTTPClient.writeTo()
This method streams the content to the outputStream Please take care to call finish()!
@param outputStream
@throws IOException
-
net.yacy.kelondro.util.ByteBuffer.writeTo()
-
org.ajax4jsf.io.FastBufferOutputStream.writeTo()
Writes all data written up to the moment to out.
@param out
@throws IOException
-
org.ajax4jsf.io.FastBufferReader.writeTo()
Writes rest of data written up to the moment to out.
@param writer
@throws IOException
-
org.ajax4jsf.io.FastBufferWriter.writeTo()
Writes all data written up to the moment to out.
@param writer
@throws IOException
-
org.apache.abdera.ext.opensearch.model.OpenSearchDescription.writeTo()
-
org.apache.abdera.model.Base.writeTo()
Serializes the model component out to the specified stream
@param out The java.io.OutputStream to use when serializing the Base. The charset encoding specified for the document will be used
-
org.apache.abdera.model.Document.writeTo()
-
org.apache.abdera.model.Element.writeTo()
-
org.apache.abdera.model.Entry.writeTo()
-
org.apache.abdera.model.Feed.writeTo()
-
org.apache.abdera.model.Service.writeTo()
-
org.apache.abdera.writer.Writer.writeTo()
Serialized the given Abdera Base to the given outputstream
-
org.apache.axiom.util.blob.OverflowBlob.writeTo()
-
org.apache.axis.Message.writeTo()
Writes this
SOAPMessage
object to the given output stream. The externalization format is as defined by the SOAP 1.1 with Attachments specification.
If there are no attachments, just an XML stream is written out. For those messages that have attachments, writeTo
writes a MIME-encoded byte stream.
@param out the
OutputStream
object to which this
SOAPMessage
object will be written
@throws SOAPException if there was a problem inexternalizing this SOAP message
@throws IOException if an I/O erroroccurs
-
org.apache.axis2.transport.MessageFormatter.writeTo()
To support deffered writing transports as in http chunking.. Axis2 was doing this for some time..
Preserve flag can be used to preserve the envelope for later use. This is usefull when implementing authentication machnisms like NTLM.
@param outputStream
@param preserve :do not consume the OM when this is set..
-
org.apache.axis2.transport.http.SOAPMessageFormatter.writeTo()
-
org.apache.cocoon.pipeline.caching.CacheValue.writeTo()
-
org.apache.commons.io.output.ByteArrayOutputStream.writeTo()
@see java.io.ByteArrayOutputStream#writeTo(OutputStream)
-
org.apache.cxf.jaxrs.provider.JAXBElementProvider.writeTo()
-
org.apache.directory.server.dhcp.options.DhcpOption.writeTo()
-
org.apache.drill.exec.proto.GeneralRPCProtos.RpcHeader.writeTo()
-
org.apache.flex.compiler.as.codegen.IASWriter.writeTo()
Start writing to output stream.
@param out output stream
-
org.apache.flex.compiler.codegen.as.IASWriter.writeTo()
Start writing to output stream.
@param out output stream
-
org.apache.flex.swf.io.ISWFWriter.writeTo()
Start writing to output stream.
@param out output stream
-
org.apache.flex.swf.io.SWFWriter.writeTo()
This method does not close the {@code output} stream.
-
org.apache.fop.afp.parser.UnparsedStructuredField.writeTo()
Writes this structured field to the given {@link OutputStream}.
@param out the output stream
@throws IOException if an I/O error occurs
-
org.apache.geronimo.corba.io.EncapsulationOutputStream.writeTo()
-
org.apache.giraph.conf.GiraphTypes.writeTo()
Write types to Configuration
@param conf Configuration
-
org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.writeTo()
-
org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.writeTo()
-
org.apache.hadoop.io.DataOutputBuffer.writeTo()
Write to a file stream
-
org.apache.hadoop.io.simpleseekableformat.DataSegmentWriter.writeTo()
Write this data segment into an OutputStream.
-
org.apache.hadoop.yarn.proto.YarnServerCommonServiceProtos.RegisterNodeManagerResponseProto.writeTo()
-
org.apache.http.HttpEntity.writeTo()
Writes the entity content to the output stream.
@param outstream the output stream to write entity content to
@throws IOException if an I/O error occurs
-
org.apache.http.entity.FileEntity.writeTo()
-
org.apache.http.entity.StringEntity.writeTo()
-
org.apache.http.entity.mime.HttpMultipart.writeTo()
Writes out the content in the multipart/form encoding. This method produces slightly different formatting depending on its compatibility mode.
@see #getMode()
-
org.apache.http.entity.mime.MultipartEntity.writeTo()
-
org.apache.http.entity.mime.content.ContentBody.writeTo()
-
org.apache.http.impl.client.cache.DefaultHttpCacheEntrySerializer.writeTo()
-
org.apache.jackrabbit.oak.plugins.segment.Segment.writeTo()
Writes this segment to the given output stream.
@param stream stream to which this segment will be written
@throws IOException on an IO error
-
org.apache.jackrabbit.oak.spi.security.privilege.PrivilegeBits.writeTo()
Write this instance as property to the specified tree.
@param tree The target tree.
-
org.apache.james.mime4j.dom.BinaryBody.writeTo()
-
org.apache.james.mime4j.dom.TextBody.writeTo()
-
org.apache.james.mime4j.message.Header.writeTo()
Write the Header to the given OutputStream.
@param out the OutputStream to write to
@param mode compatibility mode
@throws IOException if case of an I/O error
@throws MimeException if case of a MIME protocol violation
-
org.apache.james.mime4j.message.Message.writeTo()
Write the content to the given output stream using the {@link MessageWriter#DEFAULT default} message writer.
@param out the output stream to write to.
@throws IOException in case of an I/O error
@see MessageWriter
-
org.apache.kafka.common.protocol.types.Struct.writeTo()
Write this struct to a buffer
-
org.apache.kafka.common.requests.ResponseHeader.writeTo()
-
org.apache.lucene.store.RAMOutputStream.writeTo()
Copy the current contents of this buffer to the named output.
-
org.apache.maven.surefire.util.ScanResult.writeTo()
-
org.apache.poi.xssf.model.CommentsTable.writeTo()
-
org.apache.synapse.commons.util.TemporaryData.writeTo()
Write the data to a given output stream.
@param out The output stream to write the data to. This method willnot close the stream.
@throws IOException in case of an error in writing to the OutputStream
-
org.apache.tez.dag.api.records.DAGProtos.ConfigurationProto.writeTo()
-
org.apache.tez.dag.api.records.DAGProtos.DAGPlan.writeTo()
-
org.apache.trevni.avro.AvroColumnWriter.writeTo()
Write all rows added to the named output stream.
-
org.apache.wicket.markup.html.form.upload.FileUpload.writeTo()
Saves this file upload to a given file on the server side.
@param file The file
@throws IOException
-
org.apache.wicket.protocol.http.BufferedWebResponse.writeTo()
Writes the content of the buffer to the specified response. Also sets the properties and and headers.
@param response
-
org.apache.wink.common.internal.providers.entity.DataSourceProvider.writeTo()
-
org.apache.wink.common.internal.providers.entity.FormMultivaluedMapProvider.writeTo()
-
org.apache.wink.common.internal.providers.entity.ReaderProvider.writeTo()
-
org.apache.wink.common.internal.providers.entity.atom.AtomFeedProvider.writeTo()
-
org.apache.wink.common.internal.providers.entity.csv.CsvSyndFeedSerializerProvider.writeTo()
-
org.apache.wink.common.internal.providers.entity.opensearch.OpenSearchDescriptionProvider.writeTo()
-
org.box2d.proto.Box2D.PbBody.writeTo()
-
org.box2d.proto.Box2D.PbFixture.writeTo()
-
org.box2d.proto.Box2D.PbJoint.writeTo()
-
org.box2d.proto.Box2D.PbShape.writeTo()
-
org.box2d.proto.Box2D.PbWorld.writeTo()
-
org.browsermob.proxy.jetty.util.ByteArrayISO8859Writer.writeTo()
-
org.codehaus.jackson.jaxrs.JacksonJaxbJsonProvider.writeTo()
-
org.cojen.classfile.Attribute.writeTo()
This method writes the 16 bit name constant index followed by the 32 bit attribute length, followed by the attribute specific data.
-
org.earth3d.jearth.model.PartsObject.writeTo()
Writes this PartsObject into the given file. Directories are automatically created if necessary.
@param filename
@throws IOException
-
org.eclipse.jetty.util.ByteArrayISO8859Writer.writeTo()
-
org.eclipse.jgit.iplog.IpLogGenerator.writeTo()
Dump the scanned information into an XML file.
@param out the file stream to write to. The caller is responsible for closing the stream upon completion.
@throws IOException the stream cannot be written.
-
org.eclipse.jgit.util.TemporaryBuffer.writeTo()
Send this buffer to an output stream.
This method may only be invoked after {@link #close()} has completednormally, to ensure all data is completely transferred.
@param os stream to send this buffer's complete content to.
@param pm if not null progress updates are sent here. Caller should initialize the task and the number of work units to {@link #length()}/1024
.
@throws IOException an error occurred reading from a temporary file on the local system, or writing to the output stream.
-
org.elasticsearch.common.bytes.BytesReference.writeTo()
Writes the bytes directly to the output stream.
-
org.exoplatform.commons.utils.Text.writeTo()
-
org.exoplatform.services.web.css.model.StylesheetObject.writeTo()
Serialize the css to the provided writer.
@param writer the writer
@throws IOException any exception related to the writer
@throws IllegalArgumentException if the writer is null
-
org.exoplatform.ws.frameworks.json.value.JsonValue.writeTo()
Write value in given writer.
@param writer Writer.
@throws JsonException if any errors occurs.
-
org.fusesource.hawtbuf.Buffer.writeTo()
same as out.write(data, offset, length);
-
org.geoserver.wms.map.RawMap.writeTo()
-
org.glassfish.admin.rest.logviewer.CharSpool.writeTo()
-
org.glassfish.jersey.server.mvc.spi.ResolvedViewable.writeTo()
Write the resolved viewable.
This method defers to {@link TemplateProcessor#writeTo(Object,org.glassfish.jersey.server.mvc.Viewable,javax.ws.rs.core.MediaType,java.io.OutputStream)} to write the viewable utilizing the template reference.
@param out the output stream that the view processor writes to.
@throws java.io.IOException if there was an error processing the template.
-
org.globus.gsi.OpenSSLKey.writeTo()
-
org.globus.gsi.bc.BouncyCastleOpenSSLKey.writeTo()
-
org.gradle.api.java.archives.Manifest.writeTo()
Writes the manifest into a writer.
@param writer The writer to write the manifest to
@return this
-
org.gradle.api.publish.maven.internal.tasks.MavenPomFileGenerator.writeTo()
-
org.grails.buffer.StreamByteBuffer.writeTo()
-
org.h2.test.utils.OutputCatcher.writeTo()
Write the output to a HTML file.
@param title the title
@param fileName the file name
-
org.hsqldb.lib.HsqlByteArrayOutputStream.writeTo()
-
org.infinispan.protostream.UnknownFieldSet.writeTo()
Serializes the set and writes it to {@code output}.
-
org.infinispan.schematic.internal.io.BsonDataOutput.writeTo()
Write all content to the supplied stream.
@param stream the stream to which the content is to be written.
@throws IOException if there is a problem writing to the supplied stream
-
org.jasig.portal.layout.IUserLayout.writeTo()
Writes user layout content (with appropriate markings) into a ContentHandler
@param ch a ContentHandler
value
@exception PortalException if an error occurs
-
org.jboss.byteman.rule.binding.Binding.writeTo()
-
org.jboss.resteasy.core.ServerResponse.writeTo()
If there is an entity, headers are not converted to a string and set on the HttpResponse until the output stream is written to. If there is an exception thrown then the headers are never written to the response. We do this so that on error conditions there is a clean response.
@param request
@param response
@param providerFactory
@throws WriterException
-
org.jboss.ws.core.MessageAbstraction.writeTo()
-
org.jboss.ws.core.jaxws.wsaddressing.NativeEndpointReference.writeTo()
{@inheritDoc}
-
org.jboss.ws.core.soap.SOAPMessageImpl.writeTo()
-
org.jboss.ws.core.soap.XMLFragment.writeTo()
-
org.jboss.ws.core.soap.attachment.MultipartRelatedXOPEncoder.writeTo()
-
org.jboss.ws.metadata.wsdl.xmlschema.JBossXSModel.writeTo()
-
org.jbox2d.serialization.SerializationResult.writeTo()
Writes the result to the given output stream.
@param argOutputStream
@throws IOException
-
org.jf.baksmali.Adaptors.ClassDefinition.writeTo()
-
org.jf.dexlib2.analysis.RegisterType.writeTo()
-
org.jf.dexlib2.writer.builder.DexBuilder.writeTo()
-
org.jgroups.Message.writeTo()
Streams all members (dest and src addresses, buffer and headers) to the output stream.
@param out
@throws IOException
-
org.jgroups.stack.IpAddress.writeTo()
-
org.jitterbit.integration.data.structure.ldap.LdapSearchParametersPersistor.writeTo()
Writes the state of the given LdapSearchParameters
to a Persistor
.
-
org.jitterbit.integration.data.structure.ldap.LdapStructureEntryPersistor.writeTo()
Writes the state of the given LdapStructureEntry
to a Persistor
.
-
org.jitterbit.integration.data.structure.text.FieldDelimiter.writeTo()
Stores this delimiter in a Persistor
.
@see #fromPersistor(Persistor)
-
org.jnode.assembler.x86.X86BinaryAssembler.writeTo()
Write my contents to the given stream.
@param os
@throws IOException
-
org.jnode.net.ethernet.EthernetAddress.writeTo()
Write this address to a given offset in the given buffer
@param skbuf
@param skbufOffset
-
org.jnode.vm.facade.HeapStatistics.writeTo()
Write the statistical data to an {@link Appendable}.
@param a
@throws IOException
-
org.jpos.emv.EMVTagSequence.writeTo()
-
org.jpos.tlv.GenericTagSequence.writeTo()
-
org.jvnet.hk2.config.Dom.writeTo()
Writes back this element.
@param tagName The tag name of this element to be written. If null, this DOM node must be a global element and its tag name will be used.
@param w Receives XML infoset stream.
-
org.jvnet.staxex.Base64Data.writeTo()
-
org.jzkit.a2j.codec.runtime.BEROutputStream.writeTo()
-
org.kohsuke.stapler.export.Model.writeTo()
-
org.mikha.utils.net.UrlAndParams.writeTo()
Writes this URL to given {@link Writer}.
@param forHref if true
, additionally escapes &separating parameters
@param w Writer
to append to
@return original Writer
-
org.modeshape.common.collection.Problems.writeTo()
Write the problems to the supplied logger.
@param logger the logger
-
org.modeshape.common.collection.SimpleProblems.writeTo()
-
org.mortbay.resource.Resource.writeTo()
@param out
@param start First byte to write
@param count Bytes to write or -1 for all of them.
-
org.mortbay.util.ByteArrayISO8859Writer.writeTo()
-
org.onebusaway.transit_data_federation.services.service_alerts.ServiceAlerts.ServiceAlertsCollection.writeTo()
-
org.ontoware.rdf2go.model.Model.writeTo()
-
org.openflow.protocol.OFFlowMod.writeTo()
-
org.openflow.protocol.OFPacketIn.writeTo()
-
org.openflow.protocol.OFPacketOut.writeTo()
-
org.openqa.jetty.util.ByteArrayISO8859Writer.writeTo()
-
org.openqa.selenium.firefox.PreferencesWrapper.writeTo()
-
org.pdfclown.objects.PdfDictionary.writeTo()
-
org.pdfclown.objects.PdfIndirectObject.writeTo()
-
org.restlet.ext.jaxrs.internal.provider.JaxbElementProvider.writeTo()
@see MessageBodyWriter#writeTo(Object,Class,Type,Annotation[],MediaType,MultivaluedMap,OutputStream)
-
org.springframework.ws.WebServiceMessage.writeTo()
Writes the entire message to the given output stream.
If the given stream is an instance of {@link org.springframework.ws.transport.TransportOutputStream}, the corresponding headers will be written as well.
@param outputStream the stream to write to
@throws IOException if an I/O exception occurs
-
org.springframework.ws.soap.SoapMessage.writeTo()
-
org.springframework.ws.soap.axiom.AxiomSoapMessage.writeTo()
-
org.springframework.ws.soap.saaj.SaajSoapMessage.writeTo()
-
org.strecks.holidaybooking.web.struts.form.HolidayBookingForm.writeTo()
-
org.tmatesoft.svn.core.internal.server.dav.DAVResource.writeTo()
-
org.tmatesoft.svn.core.io.diff.SVNDiffInstruction.writeTo()
Wirtes this instruction to a byte buffer.
@param target a byte buffer to write to
-
org.vfny.geoserver.Response.writeTo()
Writes this respone to the provided output stream.
To implememt streaming, execution is sometimes delayed until the write opperation (for example of this see FeatureResponse). Hopefully this is okay? GR:the idea for minimize risk error at writing time, is that execute performs any needed query/processing, leaving to this method just the risk of encountering an uncaught or IO exception. i.e. FeatureResponse should execute the queries inside the execute method, and have a set of FeatureReader's (or results) ready to be streamed here. This approach fits well with the Chirs' idea of configuring geoserver for speed or full conformance, wich ends in just writing directly to the http response output stream or to a ByteArrayOutputStream
JG: Consider using a Writer here? GR: I don't think so, because not all responses will be char sequences, such as an image in a WMS GetImage response.
@param out
@throws ServiceException wrapping of any unchecked exception or otherpredictable exception except an IO error while writing to
out
@throws IOException ONLY if an error occurs trying to write content tothe passed OutputStream. By this way, we'll can control the very common situation of a java.net.SocketException product of the client closing the connection (like a user pressing it's refresh browser button many times)
-
org.vfny.geoserver.wms.responses.GetMapResponse.writeTo()
delegates the writing and encoding of the results of the request to the GetMapDelegate
wich is actually processing it, and has been obtained when execute(Request)
was called
@param out the output to where the map must be written
@throws ServiceException if the delegate throws a ServiceException inside its writeTo(OuptutStream)
, mostly due to
@throws IOException if the delegate throws an IOException inside its writeTo(OuptutStream)
, mostly due to
@throws IllegalStateException if this method is called before execute(Request)
has succeed
-
org.waveprotocol.box.server.persistence.protos.ProtoDeltaStoreData.ProtoTransformedWaveletDelta.writeTo()
-
org.wymiwyg.wrhapi.MessageBody.writeTo()
-
protobuf_unittest.UnittestProto.TestAllTypes.writeTo()
-
protobuf_unittest.UnittestProto.TestPackedTypes.writeTo()
-
railo.runtime.cache.legacy.CacheItem.writeTo()
-
test.protos.MemberProtos.MemberBook.writeTo()
-
vavi.sound.smaf.message.TrackMessage.writeTo()
-
xbird.xquery.dm.instance.DocumentTableModel.DTMNodeBase.writeTo()
-
xbird.xquery.func.BuiltInFunction.writeTo()