You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@xmlgraphics.apache.org by ac...@apache.org on 2008/08/04 11:38:03 UTC

svn commit: r682305 - in /xmlgraphics/commons/trunk: ./ src/java/org/apache/xmlgraphics/store/

Author: acumiskey
Date: Mon Aug  4 02:38:02 2008
New Revision: 682305

URL: http://svn.apache.org/viewvc?rev=682305&view=rev
Log:
Added the new org.apache.xmlgraphics.store package to provide temporary storage features.

Added:
    xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/
    xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/FileStore.java   (with props)
    xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/InputStreamStorer.java   (with props)
    xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/StoreRecord.java   (with props)
    xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/Storer.java   (with props)
    xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/Writable.java   (with props)
    xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/WritableStorer.java   (with props)
    xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/WriteSession.java   (with props)
Modified:
    xmlgraphics/commons/trunk/status.xml

Added: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/FileStore.java
URL: http://svn.apache.org/viewvc/xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/FileStore.java?rev=682305&view=auto
==============================================================================
--- xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/FileStore.java (added)
+++ xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/FileStore.java Mon Aug  4 02:38:02 2008
@@ -0,0 +1,166 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+/* $Id$ */
+
+package org.apache.xmlgraphics.store;
+
+import java.io.File;
+import java.io.FileDescriptor;
+import java.io.FileOutputStream;
+import java.io.IOException;
+import java.io.InputStream;
+import java.io.OutputStream;
+import java.io.RandomAccessFile;
+
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+import org.apache.xmlgraphics.image.loader.ImageManager;
+
+/**
+ * A useful class which is able to easily store and retrieve large resources (such as images)
+ */
+public class FileStore {
+
+    /** logger */
+    protected static Log log = LogFactory.getLog(ImageManager.class);
+
+    /** Internal temporary storage buffer size */
+    private static final int BUFFER_SIZE = 4096;
+
+    /** Used for storage of data objects */
+    protected RandomAccessFile raFile;
+
+    /** The temporary cache file */
+    private File tempFile;
+
+    /** The file outputstream */
+    protected FileOutputStream fos;
+
+    /**
+     * Default constructor
+     *
+     * @param prefix file store prefix
+     */
+    public FileStore(String prefix) {
+        try {
+            this.tempFile = File.createTempFile(prefix, null);
+            this.raFile = new RandomAccessFile(tempFile, "rw");
+            FileDescriptor fd = raFile.getFD();
+            this.fos = new FileOutputStream(fd);
+        } catch (IOException e) {
+            // TODO
+            log.error(e.getMessage());
+        }
+    }
+
+    /**
+     * Clears the resource store.
+     *
+     * @throws IOException if an error occurs while clearing the store
+     */
+    public void clear() throws IOException {
+        if (tempFile != null) {
+            raFile.close();
+            raFile = null;
+            fos = null;
+            if (tempFile.exists() && !tempFile.delete()) {
+                throw new IOException("Could not delete temporary file: " + tempFile);
+            }
+            tempFile = null;
+        }
+    }
+
+    /** {@inheritDoc} */
+    public void finalize() throws Throwable {
+        try {
+            clear();
+        } finally {
+            super.finalize();
+        }
+    }
+
+    /**
+     * Returns the storer of a given object
+     *
+     * @param object an object to be stored
+     * @return a storer of the object
+     */
+    protected Storer getStorer(Object object) {
+        Storer storer;
+        if (object instanceof Writable) {
+            storer = new WritableStorer(this, (Writable)object);
+        } else if (object instanceof InputStream) {
+            storer = new InputStreamStorer(this, (InputStream)object);
+        } else {
+            throw new IllegalArgumentException("Unsupported object " + object);
+        }
+        return storer;
+    }
+
+    /**
+     * Stores an object in the cache
+     *
+     * @param object the object to store
+     * @return a new save information record
+     *
+     * @throws java.io.IOException an I/O exception of some sort has occurred.
+     */
+    public StoreRecord write(Object object) throws IOException {
+        return getStorer(object).store();
+    }
+
+    /**
+     * Reads all the data from a given store information record
+     * and returns it in a byte array.
+     * This is potentially a memory hungry operation so use with care.
+     *
+     * @param storeInfo a store information record
+     * @return the stored data in a byte array.
+     * @throws java.io.IOException an I/O exception of some sort has occurred.
+     */
+    public byte[] read(StoreRecord storeInfo) throws IOException {
+        raFile.seek(storeInfo.position);
+        byte[] buff = new byte[storeInfo.size];
+        raFile.read(buff);
+        return buff;
+    }
+
+    /**
+     * Writes out the resource in full using the store information to the given outputstream.
+     *
+     * @param storeInfo the save information
+     * @param os the outputstream to write to
+     *
+     * @throws java.io.IOException an I/O exception of some sort has occurred.
+     */
+    public void writeToStream(StoreRecord storeInfo, OutputStream os) throws IOException {
+        if (storeInfo == null) {
+            throw new IllegalArgumentException("save is null");
+        }
+        double chunkCount = storeInfo.size / BUFFER_SIZE;
+        byte[] buffer = new byte[BUFFER_SIZE];
+        raFile.seek(storeInfo.position);
+        for (int cnt = 0; cnt < chunkCount; cnt++) {
+            raFile.read(buffer, 0, BUFFER_SIZE);
+            os.write(buffer, 0, BUFFER_SIZE);
+        }
+        int lastChunkLength = storeInfo.size % BUFFER_SIZE;
+        raFile.read(buffer, 0, lastChunkLength);
+        os.write(buffer, 0, lastChunkLength);
+    }
+}

Propchange: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/FileStore.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/FileStore.java
------------------------------------------------------------------------------
    svn:keywords = Revision Id

Added: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/InputStreamStorer.java
URL: http://svn.apache.org/viewvc/xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/InputStreamStorer.java?rev=682305&view=auto
==============================================================================
--- xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/InputStreamStorer.java (added)
+++ xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/InputStreamStorer.java Mon Aug  4 02:38:02 2008
@@ -0,0 +1,31 @@
+package org.apache.xmlgraphics.store;
+
+import java.io.IOException;
+import java.io.InputStream;
+
+import org.apache.commons.io.IOUtils;
+
+/**
+ * Storer of InputStreams
+ */
+public final class InputStreamStorer extends Storer {
+
+    /** an inputstream */
+    private final InputStream in;
+
+    /**
+     * Constructor
+     *
+     * @param store our resource store
+     * @param in an inputstream
+     */
+    protected InputStreamStorer(FileStore store, InputStream in) {
+        super(store);
+        this.in = in;
+    }
+
+    /** {@inheritDoc} */
+    protected void doStore() throws IOException {
+        IOUtils.copy(in, store.fos);
+    }
+}
\ No newline at end of file

Propchange: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/InputStreamStorer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/InputStreamStorer.java
------------------------------------------------------------------------------
    svn:keywords = Revision Id

Added: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/StoreRecord.java
URL: http://svn.apache.org/viewvc/xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/StoreRecord.java?rev=682305&view=auto
==============================================================================
--- xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/StoreRecord.java (added)
+++ xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/StoreRecord.java Mon Aug  4 02:38:02 2008
@@ -0,0 +1,90 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+/* $Id$ */
+
+package org.apache.xmlgraphics.store;
+
+import java.io.IOException;
+import java.io.OutputStream;
+
+/**
+ * Store save information
+ */
+public class StoreRecord {
+
+    /** the resource store associated with this store information */
+    private final FileStore store;
+
+    /** data position */
+    protected long position;
+
+    /** data chunk size */
+    protected int size;
+
+    /**
+     * Main constructor
+     *
+     * @param store our resource store
+     */
+    public StoreRecord(FileStore store) {
+        this.store = store;
+    }
+
+    /**
+     * Returns the storage position
+     *
+     * @return the storage position
+     */
+    public long getPosition() {
+        return this.position;
+    }
+
+    /**
+     * Returns the storage size
+     *
+     * @return the storage size
+     */
+    public int getLength() {
+        return this.size;
+    }
+
+    /**
+     * Returns the resource store associated with this store record
+     *
+     * @return the resource store associated with this store record
+     */
+    public FileStore getStore() {
+        return this.store;
+    }
+
+    /**
+     * Convenience method used to writes the data referenced
+     * by this storage record to an outputstream
+     *
+     * @param os the outputstream to write to
+     * @throws java.io.IOException an I/O exception of some sort has occurred.
+     */
+    public void writeToStream(OutputStream os) throws IOException {
+        store.writeToStream(this, os);
+    }
+
+    /** {@inheritDoc} */
+    public String toString() {
+        return "pos=" + position + ", size=" + size;
+    }
+}
\ No newline at end of file

Propchange: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/StoreRecord.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/StoreRecord.java
------------------------------------------------------------------------------
    svn:keywords = Revision Id

Added: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/Storer.java
URL: http://svn.apache.org/viewvc/xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/Storer.java?rev=682305&view=auto
==============================================================================
--- xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/Storer.java (added)
+++ xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/Storer.java Mon Aug  4 02:38:02 2008
@@ -0,0 +1,87 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+/* $Id$ */
+
+package org.apache.xmlgraphics.store;
+
+import java.io.IOException;
+
+/**
+ * Base storer class
+ */
+public class Storer {
+
+    /** write session */
+    protected final WriteSession session;
+
+    /** file store */
+    protected final FileStore store;
+
+    /**
+     * Constructor
+     *
+     * @param store our resource store
+     */
+    public Storer(FileStore store) {
+        this.store = store;
+        this.session = new WriteSession(this);
+    }
+
+    /**
+     * Instantiates the store information record
+     *
+     * @return a new store information record
+     */
+    protected StoreRecord createRecord() {
+        return new StoreRecord(store);
+    }
+
+    /**
+     * Stores the object
+     *
+     * @return a store information record
+     * @throws IOException thrown if an I/O exception of some sort has occurred.
+     */
+    public StoreRecord store() throws IOException {
+        StoreRecord record = null;
+        session.begin();
+        try {
+            doStore();
+        } finally {
+            record = session.end();
+        }
+        return record;
+    }
+
+    /**
+     * Actually performs the store operation
+     *
+     * @throws IOException thrown if an I/O exception of some sort has occurred.
+     */
+    protected void doStore() throws IOException {
+    }
+
+    /**
+     * Returns the file store associated with this storer
+     *
+     * @return the file store associated with this storer
+     */
+    protected FileStore getStore() {
+        return store;
+    }
+}

Propchange: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/Storer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/Storer.java
------------------------------------------------------------------------------
    svn:keywords = Revision Id

Added: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/Writable.java
URL: http://svn.apache.org/viewvc/xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/Writable.java?rev=682305&view=auto
==============================================================================
--- xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/Writable.java (added)
+++ xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/Writable.java Mon Aug  4 02:38:02 2008
@@ -0,0 +1,38 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+/* $Id$ */
+
+package org.apache.xmlgraphics.store;
+
+import java.io.IOException;
+import java.io.OutputStream;
+
+/**
+ * Implementing object is able to write to an OutputStream
+ */
+public interface Writable {
+
+    /**
+     * DataStream objects must implement the writeToStream()
+     * method to write its data to the given OutputStream
+     *
+     * @param outputStream The outputsteam stream
+     * @throws java.io.IOException an I/O exception of some sort has occurred.
+     */
+    void writeToStream(OutputStream outputStream) throws IOException;
+}

Propchange: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/Writable.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/Writable.java
------------------------------------------------------------------------------
    svn:keywords = Revision Id

Added: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/WritableStorer.java
URL: http://svn.apache.org/viewvc/xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/WritableStorer.java?rev=682305&view=auto
==============================================================================
--- xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/WritableStorer.java (added)
+++ xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/WritableStorer.java Mon Aug  4 02:38:02 2008
@@ -0,0 +1,47 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+/* $Id$ */
+
+package org.apache.xmlgraphics.store;
+
+import java.io.IOException;
+
+/**
+ * Storer of objects that implement the Writable interface
+ */
+public class WritableStorer extends Storer {
+
+    /** a Writable object */
+    protected final Writable writable;
+
+    /**
+     * Constructor
+     *
+     * @param store our resource store
+     * @param writable an object implementing the Writable interface
+     */
+    public WritableStorer(FileStore store, Writable writable) {
+        super(store);
+        this.writable = writable;
+    }
+
+    /** {@inheritDoc} */
+    protected void doStore() throws IOException {
+        writable.writeToStream(store.fos);
+    }
+}

Propchange: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/WritableStorer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/WritableStorer.java
------------------------------------------------------------------------------
    svn:keywords = Revision Id

Added: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/WriteSession.java
URL: http://svn.apache.org/viewvc/xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/WriteSession.java?rev=682305&view=auto
==============================================================================
--- xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/WriteSession.java (added)
+++ xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/WriteSession.java Mon Aug  4 02:38:02 2008
@@ -0,0 +1,109 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+/* $Id$ */
+
+package org.apache.xmlgraphics.store;
+
+import java.io.IOException;
+import java.io.OutputStream;
+
+/**
+ * A Write session
+ */
+public class WriteSession {
+    /** true if the session output was flushed */
+    protected boolean flushed = false;
+
+    /** the session storer */
+    private final Storer storer;
+
+    /** the storer's file store */
+    private final FileStore store;
+
+    /** the store information record */
+    protected StoreRecord record;
+
+    /**
+     * Constructor
+     *
+     * @param store our store
+     */
+    public WriteSession(FileStore store) {
+        this.storer = new Storer(store);
+        this.store = store;
+    }
+
+    /**
+     * Constructor
+     *
+     * @param storer our storer
+     */
+    public WriteSession(Storer storer) {
+        this.storer = storer;
+        this.store = storer.getStore();
+    }
+
+    /**
+     * Begins the session
+     *
+     * @throws IOException thrown if an I/O exception of some sort has occurred.
+     */
+    public void begin() throws IOException {
+        // always write to the end of the store
+        long length = store.raFile.length();
+        if (store.raFile.getFilePointer() < length) {
+            store.raFile.seek(length);
+        }
+
+        this.record = storer.createRecord();
+        record.position = store.raFile.getFilePointer();
+    }
+
+    /**
+     * Ends the session
+     *
+     * @return a new store information record
+     * @throws IOException thrown if an I/O exception of some sort has occurred.
+     */
+    public StoreRecord end() throws IOException {
+        if (!flushed) {
+            store.fos.flush();
+            flushed = true;
+        }
+        record.size = (int)(store.raFile.getFilePointer() - record.position);
+        return record;
+    }
+
+    /**
+     * Returns the outputstream of this store
+     *
+     * @return the outputstream of this store
+     */
+    public OutputStream getOutputStream() {
+        return store.fos;
+    }
+
+    /**
+     * Returns the store record
+     *
+     * @return the store record
+     */
+    public StoreRecord getRecord() {
+        return record;
+    }
+}
\ No newline at end of file

Propchange: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/WriteSession.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/WriteSession.java
------------------------------------------------------------------------------
    svn:keywords = Revision Id

Modified: xmlgraphics/commons/trunk/status.xml
URL: http://svn.apache.org/viewvc/xmlgraphics/commons/trunk/status.xml?rev=682305&r1=682304&r2=682305&view=diff
==============================================================================
--- xmlgraphics/commons/trunk/status.xml (original)
+++ xmlgraphics/commons/trunk/status.xml Mon Aug  4 02:38:02 2008
@@ -40,6 +40,9 @@
   </contexts>
   <changes>
     <release version="Trunk" date="n/a">
+      <action context="Code" dev="AC" type="add">
+        Added the new org.apache.xmlgraphics.store package to provide temporary storage features.
+      </action>
       <action context="Code" dev="JM" type="fix">
         Bugfix: Added missing start/endPrefixMapping() calls when serializing XMP packets.
       </action>



---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@xmlgraphics.apache.org
For additional commands, e-mail: commits-help@xmlgraphics.apache.org


Re: svn commit: r682305 - in /xmlgraphics/commons/trunk: ./ src/java/org/apache/xmlgraphics/store/

Posted by Jeremias Maerki <de...@jeremias-maerki.ch>.
Sorry Adrian, but I'm -1 on that commit. You barely left the weekend to
react on your proposal. IMO, XGC is not the right place for this. I
don't see a high reusability factor in this code, it has very little to
do with XML and graphics and it is only used by one component inside FOP.
I don't see that Batik will ever need this package. Will reply in to
your proposal as well.

On 04.08.2008 11:38:03 acumiskey wrote:
> Author: acumiskey
> Date: Mon Aug  4 02:38:02 2008
> New Revision: 682305
> 
> URL: http://svn.apache.org/viewvc?rev=682305&view=rev
> Log:
> Added the new org.apache.xmlgraphics.store package to provide temporary storage features.
> 
> Added:
>     xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/
>     xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/FileStore.java   (with props)
>     xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/InputStreamStorer.java   (with props)
>     xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/StoreRecord.java   (with props)
>     xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/Storer.java   (with props)
>     xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/Writable.java   (with props)
>     xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/WritableStorer.java   (with props)
>     xmlgraphics/commons/trunk/src/java/org/apache/xmlgraphics/store/WriteSession.java   (with props)
> Modified:
>     xmlgraphics/commons/trunk/status.xml
<snip/>



Jeremias Maerki


---------------------------------------------------------------------
Apache XML Graphics Project URL: http://xmlgraphics.apache.org/
To unsubscribe, e-mail: general-unsubscribe@xmlgraphics.apache.org
For additional commands, e-mail: general-help@xmlgraphics.apache.org