You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@xalan.apache.org by mr...@apache.org on 2011/12/29 05:13:09 UTC

svn commit: r1225426 [7/19] - in /xalan/java/trunk/src: ./ org/apache/xalan/ org/apache/xalan/res/ org/apache/xalan/xsltc/compiler/util/ org/apache/xalan/xsltc/dom/ org/apache/xalan/xsltc/runtime/ org/apache/xml/dtm/ org/apache/xml/res/ org/apache/xml/...

Modified: xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/InternalError.java
URL: http://svn.apache.org/viewvc/xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/InternalError.java?rev=1225426&r1=1225425&r2=1225426&view=diff
==============================================================================
--- xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/InternalError.java (original)
+++ xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/InternalError.java Thu Dec 29 04:13:08 2011
@@ -1,36 +1,36 @@
-/*
- * 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.xalan.xsltc.compiler.util;
-
-/**
- * Marks a class of errors in which XSLTC has reached some incorrect internal
- * state from which it cannot recover.
- */
-public class InternalError extends Error {
-    /**
-     * Construct an <code>InternalError</code> with the specified error message.
-     * @param msg the error message
-     */
-    public InternalError(String msg) {
-        super(msg);
-    }
-}
+/*
+ * 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.xalan.xsltc.compiler.util;
+
+/**
+ * Marks a class of errors in which XSLTC has reached some incorrect internal
+ * state from which it cannot recover.
+ */
+public class InternalError extends Error {
+    /**
+     * Construct an <code>InternalError</code> with the specified error message.
+     * @param msg the error message
+     */
+    public InternalError(String msg) {
+        super(msg);
+    }
+}

Propchange: xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/InternalError.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/InternalError.java
------------------------------------------------------------------------------
    svn:keywords = Author Date Id Revision

Modified: xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/MarkerInstruction.java
URL: http://svn.apache.org/viewvc/xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/MarkerInstruction.java?rev=1225426&r1=1225425&r2=1225426&view=diff
==============================================================================
--- xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/MarkerInstruction.java (original)
+++ xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/MarkerInstruction.java Thu Dec 29 04:13:08 2011
@@ -1,97 +1,97 @@
-/*
- * 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.xalan.xsltc.compiler.util;
-
-import java.io.DataOutputStream;
-import java.io.IOException;
-
-import org.apache.bcel.Constants;
-import org.apache.bcel.generic.ConstantPoolGen;
-import org.apache.bcel.generic.Instruction;
-import org.apache.bcel.generic.Visitor;
-
-/**
- * A special abstract dummy subclass of
- * {@link org.apache.bcel.generic.Instruction} used to mark locations of
- * interest in an {@link org.apache.bcel.generic.InstructionList}.  It and
- * its subclasses are only used as placeholders, and do not contribute to the
- * actual byte code instruction stream.
- */
-abstract class MarkerInstruction extends Instruction {
-    /**
-     * Zero-argument constructor.  Sets the opcode to an invalid value and 
-     * sets the length to zero, as it will not be written as part of the
-     * generated byte code.
-     */
-    public MarkerInstruction() {
-        super(Constants.UNDEFINED, (short) 0);
-    }
-
-    /**
-     * {@link org.apache.bcel.generic.Visitor}s will know nothing about this
-     * kind of {@link org.apche.bcel.generic.Instruction}, so this method does
-     * nothing.
-     */
-    public void accept(Visitor v) {
-    }
-
-    /**
-     * The number of JVM stack entries consumed by the instruction.
-     * This instruction is just a place holder, so it does not consume any
-     * stack entries.
-     * @param cpg The {@link org.apache.bcel.generic.ConstantPoolGen} for the
-     * current {@link org.apache.bcel.generic.ClassGen}
-     * @return <code>0</code> always 
-     */
-    final public int consumeStack(ConstantPoolGen cpg) {
-        return 0;
-    }
-    /**
-     * The number of JVM stack entries produced by the instruction.
-     * This instruction is just a place holder, so it does not produce any
-     * stack entries.
-     * @param cpg The {@link org.apache.bcel.generic.ConstantPoolGen} for the
-     * current {@link org.apache.bcel.generic.ClassGen}
-     * @return <code>0</code> always 
-     */
-    final public int produceStack(ConstantPoolGen cpg) {
-        return 0;
-    }
-
-    /**
-     * Produce a copy of the instruction.  By default a
-     * {@link MarkerInstruction} has no parameters, so the base implementation
-     * of {@link #copy()} returns the instruction itself.
-     * @return The instruction itself.
-     */
-    public Instruction copy() {
-        return this;
-    }
-    /**
-     * Dump instruction as byte code to stream out.  A {@link MarkerInstruction}
-     * has no effect on the generated byte code so it is never emitted to the
-     * output stream.
-     * @param out Output stream
-     */
-    final public void dump(DataOutputStream out) throws IOException {
-    }
-}
+/*
+ * 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.xalan.xsltc.compiler.util;
+
+import java.io.DataOutputStream;
+import java.io.IOException;
+
+import org.apache.bcel.Constants;
+import org.apache.bcel.generic.ConstantPoolGen;
+import org.apache.bcel.generic.Instruction;
+import org.apache.bcel.generic.Visitor;
+
+/**
+ * A special abstract dummy subclass of
+ * {@link org.apache.bcel.generic.Instruction} used to mark locations of
+ * interest in an {@link org.apache.bcel.generic.InstructionList}.  It and
+ * its subclasses are only used as placeholders, and do not contribute to the
+ * actual byte code instruction stream.
+ */
+abstract class MarkerInstruction extends Instruction {
+    /**
+     * Zero-argument constructor.  Sets the opcode to an invalid value and 
+     * sets the length to zero, as it will not be written as part of the
+     * generated byte code.
+     */
+    public MarkerInstruction() {
+        super(Constants.UNDEFINED, (short) 0);
+    }
+
+    /**
+     * {@link org.apache.bcel.generic.Visitor}s will know nothing about this
+     * kind of {@link org.apche.bcel.generic.Instruction}, so this method does
+     * nothing.
+     */
+    public void accept(Visitor v) {
+    }
+
+    /**
+     * The number of JVM stack entries consumed by the instruction.
+     * This instruction is just a place holder, so it does not consume any
+     * stack entries.
+     * @param cpg The {@link org.apache.bcel.generic.ConstantPoolGen} for the
+     * current {@link org.apache.bcel.generic.ClassGen}
+     * @return <code>0</code> always 
+     */
+    final public int consumeStack(ConstantPoolGen cpg) {
+        return 0;
+    }
+    /**
+     * The number of JVM stack entries produced by the instruction.
+     * This instruction is just a place holder, so it does not produce any
+     * stack entries.
+     * @param cpg The {@link org.apache.bcel.generic.ConstantPoolGen} for the
+     * current {@link org.apache.bcel.generic.ClassGen}
+     * @return <code>0</code> always 
+     */
+    final public int produceStack(ConstantPoolGen cpg) {
+        return 0;
+    }
+
+    /**
+     * Produce a copy of the instruction.  By default a
+     * {@link MarkerInstruction} has no parameters, so the base implementation
+     * of {@link #copy()} returns the instruction itself.
+     * @return The instruction itself.
+     */
+    public Instruction copy() {
+        return this;
+    }
+    /**
+     * Dump instruction as byte code to stream out.  A {@link MarkerInstruction}
+     * has no effect on the generated byte code so it is never emitted to the
+     * output stream.
+     * @param out Output stream
+     */
+    final public void dump(DataOutputStream out) throws IOException {
+    }
+}

Propchange: xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/MarkerInstruction.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/MarkerInstruction.java
------------------------------------------------------------------------------
    svn:keywords = Author Date Id Revision

Modified: xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/OutlineableChunkEnd.java
URL: http://svn.apache.org/viewvc/xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/OutlineableChunkEnd.java?rev=1225426&r1=1225425&r2=1225426&view=diff
==============================================================================
--- xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/OutlineableChunkEnd.java (original)
+++ xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/OutlineableChunkEnd.java Thu Dec 29 04:13:08 2011
@@ -1,70 +1,70 @@
-/*
- * 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.xalan.xsltc.compiler.util;
-
-import org.apache.bcel.generic.Instruction;
-
-/**
- * <p>Marks the end of a region of byte code that can be copied into a new
- * method.  See the {@link OutlineableChunkStart} pseudo-instruction for
- * details.</p>
- */
-class OutlineableChunkEnd extends MarkerInstruction {
-    /**
-     * A constant instance of {@link OutlineableChunkEnd}.  As it has no fields,
-     * there should be no need to create an instance of this class. 
-     */
-    public static final Instruction OUTLINEABLECHUNKEND =
-                                                new OutlineableChunkEnd();
-
-    /**
-     * Private default constructor.  As it has no fields,
-     * there should be no need to create an instance of this class.  See
-     * {@link OutlineableChunkEnd#OUTLINEABLECHUNKEND}.
-     */
-    private OutlineableChunkEnd() {
-    }
-
-    /**
-     * Get the name of this instruction.  Used for debugging.
-     * @return the instruction name
-     */
-    public String getName() {
-        return OutlineableChunkEnd.class.getName();
-    }
-
-    /**
-     * Get the name of this instruction.  Used for debugging.
-     * @return the instruction name
-     */
-    public String toString() {
-        return getName();
-    }
-
-    /**
-     * Get the name of this instruction.  Used for debugging.
-     * @return the instruction name
-     */
-    public String toString(boolean verbose) {
-        return getName();
-    }
-}
+/*
+ * 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.xalan.xsltc.compiler.util;
+
+import org.apache.bcel.generic.Instruction;
+
+/**
+ * <p>Marks the end of a region of byte code that can be copied into a new
+ * method.  See the {@link OutlineableChunkStart} pseudo-instruction for
+ * details.</p>
+ */
+class OutlineableChunkEnd extends MarkerInstruction {
+    /**
+     * A constant instance of {@link OutlineableChunkEnd}.  As it has no fields,
+     * there should be no need to create an instance of this class. 
+     */
+    public static final Instruction OUTLINEABLECHUNKEND =
+                                                new OutlineableChunkEnd();
+
+    /**
+     * Private default constructor.  As it has no fields,
+     * there should be no need to create an instance of this class.  See
+     * {@link OutlineableChunkEnd#OUTLINEABLECHUNKEND}.
+     */
+    private OutlineableChunkEnd() {
+    }
+
+    /**
+     * Get the name of this instruction.  Used for debugging.
+     * @return the instruction name
+     */
+    public String getName() {
+        return OutlineableChunkEnd.class.getName();
+    }
+
+    /**
+     * Get the name of this instruction.  Used for debugging.
+     * @return the instruction name
+     */
+    public String toString() {
+        return getName();
+    }
+
+    /**
+     * Get the name of this instruction.  Used for debugging.
+     * @return the instruction name
+     */
+    public String toString(boolean verbose) {
+        return getName();
+    }
+}

Propchange: xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/OutlineableChunkEnd.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/OutlineableChunkEnd.java
------------------------------------------------------------------------------
    svn:keywords = Author Date Id Revision

Modified: xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/OutlineableChunkStart.java
URL: http://svn.apache.org/viewvc/xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/OutlineableChunkStart.java?rev=1225426&r1=1225425&r2=1225426&view=diff
==============================================================================
--- xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/OutlineableChunkStart.java (original)
+++ xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/OutlineableChunkStart.java Thu Dec 29 04:13:08 2011
@@ -1,79 +1,79 @@
-/*
- * 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.xalan.xsltc.compiler.util;
-
-import org.apache.bcel.generic.Instruction;
-
-/**
- * <p>This pseudo-instruction marks the beginning of a region of byte code that
- * can be copied into a new method, termed an "outlineable" chunk.  The size of
- * the Java stack must be the same at the start of the region as it is at the
- * end of the region, any value on the stack at the start of the region must not
- * be consumed by an instruction in the region of code, the region must not
- * contain a return instruction, no branch instruction in the region is
- * permitted to have a target that is outside the region, and no branch
- * instruction outside the region is permitted to have a target that is inside
- * the region.</p>
- * <p>The end of the region is marked by an {@link OutlineableChunkEnd}
- * pseudo-instruction.</p>
- * <p>Such a region of code may contain other outlineable regions.</p>
- */
-class OutlineableChunkStart extends MarkerInstruction {
-    /**
-     * A constant instance of {@link OutlineableChunkStart}.  As it has no fields,
-     * there should be no need to create an instance of this class. 
-     */
-    public static final Instruction OUTLINEABLECHUNKSTART =
-                                                new OutlineableChunkStart();
-
-    /**
-     * Private default constructor.  As it has no fields,
-     * there should be no need to create an instance of this class.  See
-     * {@link OutlineableChunkStart#OUTLINEABLECHUNKSTART}.
-     */
-    private OutlineableChunkStart() {
-    }
-
-    /**
-     * Get the name of this instruction.  Used for debugging.
-     * @return the instruction name
-     */
-    public String getName() {
-        return OutlineableChunkStart.class.getName();
-    }
-
-    /**
-     * Get the name of this instruction.  Used for debugging.
-     * @return the instruction name
-     */
-    public String toString() {
-        return getName();
-    }
-
-    /**
-     * Get the name of this instruction.  Used for debugging.
-     * @return the instruction name
-     */
-    public String toString(boolean verbose) {
-        return getName();
-    }
-}
+/*
+ * 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.xalan.xsltc.compiler.util;
+
+import org.apache.bcel.generic.Instruction;
+
+/**
+ * <p>This pseudo-instruction marks the beginning of a region of byte code that
+ * can be copied into a new method, termed an "outlineable" chunk.  The size of
+ * the Java stack must be the same at the start of the region as it is at the
+ * end of the region, any value on the stack at the start of the region must not
+ * be consumed by an instruction in the region of code, the region must not
+ * contain a return instruction, no branch instruction in the region is
+ * permitted to have a target that is outside the region, and no branch
+ * instruction outside the region is permitted to have a target that is inside
+ * the region.</p>
+ * <p>The end of the region is marked by an {@link OutlineableChunkEnd}
+ * pseudo-instruction.</p>
+ * <p>Such a region of code may contain other outlineable regions.</p>
+ */
+class OutlineableChunkStart extends MarkerInstruction {
+    /**
+     * A constant instance of {@link OutlineableChunkStart}.  As it has no fields,
+     * there should be no need to create an instance of this class. 
+     */
+    public static final Instruction OUTLINEABLECHUNKSTART =
+                                                new OutlineableChunkStart();
+
+    /**
+     * Private default constructor.  As it has no fields,
+     * there should be no need to create an instance of this class.  See
+     * {@link OutlineableChunkStart#OUTLINEABLECHUNKSTART}.
+     */
+    private OutlineableChunkStart() {
+    }
+
+    /**
+     * Get the name of this instruction.  Used for debugging.
+     * @return the instruction name
+     */
+    public String getName() {
+        return OutlineableChunkStart.class.getName();
+    }
+
+    /**
+     * Get the name of this instruction.  Used for debugging.
+     * @return the instruction name
+     */
+    public String toString() {
+        return getName();
+    }
+
+    /**
+     * Get the name of this instruction.  Used for debugging.
+     * @return the instruction name
+     */
+    public String toString(boolean verbose) {
+        return getName();
+    }
+}

Propchange: xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/OutlineableChunkStart.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: xalan/java/trunk/src/org/apache/xalan/xsltc/compiler/util/OutlineableChunkStart.java
------------------------------------------------------------------------------
    svn:keywords = Author Date Id Revision

Propchange: xalan/java/trunk/src/org/apache/xalan/xsltc/dom/ArrayNodeListIterator.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: xalan/java/trunk/src/org/apache/xalan/xsltc/dom/ArrayNodeListIterator.java
------------------------------------------------------------------------------
    svn:keywords = Author Date Id Revision

Modified: xalan/java/trunk/src/org/apache/xalan/xsltc/dom/MultiValuedNodeHeapIterator.java
URL: http://svn.apache.org/viewvc/xalan/java/trunk/src/org/apache/xalan/xsltc/dom/MultiValuedNodeHeapIterator.java?rev=1225426&r1=1225425&r2=1225426&view=diff
==============================================================================
--- xalan/java/trunk/src/org/apache/xalan/xsltc/dom/MultiValuedNodeHeapIterator.java (original)
+++ xalan/java/trunk/src/org/apache/xalan/xsltc/dom/MultiValuedNodeHeapIterator.java Thu Dec 29 04:13:08 2011
@@ -1,294 +1,294 @@
-/*
- * 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: UnionIterator.java 337874 2004-02-16 23:06:53Z minchau $
- */
-
-package org.apache.xalan.xsltc.dom;
-
-import org.apache.xalan.xsltc.DOM;
-import org.apache.xalan.xsltc.runtime.BasisLibrary;
-import org.apache.xml.dtm.DTMAxisIterator;
-import org.apache.xml.dtm.ref.DTMAxisIteratorBase;
-
-/**
- * <p><code>MultiValuedNodeHeapIterator</code> takes a set of multi-valued
- * heap nodes and produces a merged NodeSet in document order with duplicates
- * removed.</p>
- * <p>Each multi-valued heap node (which might be a
- * {@link org.apache.xml.dtm.DTMAxisIterator}, but that's  not necessary)
- * generates DTM node handles in document order.  The class
- * maintains the multi-valued heap nodes in a heap, not surprisingly, sorted by
- * the next DTM node handle available form the heap node.</p>
- * <p>After a DTM node is pulled from the heap node that's at the top of the
- * heap, the heap node is advanced to the next DTM node handle it makes
- * available, and the heap nature of the heap is restored to ensure the next
- * DTM node handle pulled is next in document order overall.
- *
- * @author Jacek Ambroziak
- * @author Santiago Pericas-Geertsen
- */
-public abstract class MultiValuedNodeHeapIterator extends DTMAxisIteratorBase {
-    /** wrapper for NodeIterators to support iterator
-	comparison on the value of their next() method
-    */
-
-    /**
-     * An abstract representation of a set of nodes that will be retrieved in
-     * document order.
-     */
-    public abstract class HeapNode implements Cloneable {
-	protected int _node, _markedNode;
-	protected boolean _isStartSet = false;
-		
-        /**
-         * Advance to the next node represented by this {@link HeapNode}
-         *
-         * @return the next DTM node.
-         */
-	public abstract int step();
-
-
-        /**
-         * Creates a deep copy of this {@link HeapNode}.  The clone is not
-         * reset from the current position of the original.
-         *
-         * @return the cloned heap node
-         */
-	public HeapNode cloneHeapNode() {
-            HeapNode clone;
-
-            try {
-                clone = (HeapNode) super.clone();
-            } catch (CloneNotSupportedException e) {
-                BasisLibrary.runTimeError(BasisLibrary.ITERATOR_CLONE_ERR,
-                                          e.toString());
-                return null;
-            }
-
-	    clone._node = _node;
-	    clone._markedNode = _node;
-
-	    return clone;
-	}
-
-        /**
-         * Remembers the current node for the next call to {@link #gotoMark()}.
-         */
-	public void setMark() {
-	    _markedNode = _node;
-	}
-
-        /**
-         * Restores the current node remembered by {@link #setMark()}.
-         */
-	public void gotoMark() {
-	    _node = _markedNode;
-	}
-
-        /**
-         * Performs a comparison of the two heap nodes
-         *
-         * @param heapNode the heap node against which to compare
-         * @return <code>true</code> if and only if the current node for this
-         *         heap node is before the current node of the argument heap
-         *         node in document order.
-         */
-        public abstract boolean isLessThan(HeapNode heapNode);
-
-        /**
-         * Sets context with respect to which this heap node is evaluated.
-         *
-         * @param node The new context node
-         * @return a {@link HeapNode} which may or may not be the same as
-         *         this <code>HeapNode</code>.
-         */
-        public abstract HeapNode setStartNode(int node);
-
-        /**
-         * Reset the heap node back to its beginning.
-         *
-         * @return a {@link HeapNode} which may or may not be the same as
-         *         this <code>HeapNode</code>.
-         */
-        public abstract HeapNode reset();
-    } // end of HeapNode
-
-    private static final int InitSize = 8;
-  
-    private int        _heapSize = 0;
-    private int        _size = InitSize;
-    private HeapNode[] _heap = new HeapNode[InitSize];
-    private int        _free = 0;
-  
-    // Last node returned by this MultiValuedNodeHeapIterator to the caller of
-    // next; used to prune duplicates
-    private int _returnedLast;
-
-    // cached returned last for use in gotoMark
-    private int _cachedReturnedLast = END;
-
-    // cached heap size for use in gotoMark
-    private int _cachedHeapSize;
-
-
-    public DTMAxisIterator cloneIterator() {
-	_isRestartable = false;
-	final HeapNode[] heapCopy = new HeapNode[_heap.length];
-	try {
-	    MultiValuedNodeHeapIterator clone =
-                    (MultiValuedNodeHeapIterator)super.clone();
-
-            for (int i = 0; i < _free; i++) {
-                heapCopy[i] = _heap[i].cloneHeapNode();
-            }
-	    clone.setRestartable(false);
-	    clone._heap = heapCopy;
-	    return clone.reset();
-	} 
-	catch (CloneNotSupportedException e) {
-	    BasisLibrary.runTimeError(BasisLibrary.ITERATOR_CLONE_ERR,
-				      e.toString());
-	    return null;
-	}
-    }
-    
-    protected void addHeapNode(HeapNode node) {
-	if (_free == _size) {
-	    HeapNode[] newArray = new HeapNode[_size *= 2];
-	    System.arraycopy(_heap, 0, newArray, 0, _free);
-	    _heap = newArray;
-	}
-	_heapSize++;
-	_heap[_free++] = node;
-    }
-  
-    public int next() {
-	while (_heapSize > 0) {
-	    final int smallest = _heap[0]._node;
-	    if (smallest == END) { // iterator _heap[0] is done
-		if (_heapSize > 1) {
-		    // Swap first and last (iterator must be restartable)
-		    final HeapNode temp = _heap[0];
-		    _heap[0] = _heap[--_heapSize];
-		    _heap[_heapSize] = temp;
-		}
-		else {
-		    return END;
-		}
-	    }
-	    else if (smallest == _returnedLast) {	// duplicate
-		_heap[0].step(); // value consumed
-	    }
-	    else {
-		_heap[0].step(); // value consumed
-		heapify(0);
-		return returnNode(_returnedLast = smallest);
-	    }
-	    // fallthrough if not returned above
-	    heapify(0);
-	}
-	return END;
-    }
-  
-    public DTMAxisIterator setStartNode(int node) {
-	if (_isRestartable) {
-	    _startNode = node;
-	    for (int i = 0; i < _free; i++) {
-         	if(!_heap[i]._isStartSet){
-        	   _heap[i].setStartNode(node);
-        	   _heap[i].step();	// to get the first node
-        	   _heap[i]._isStartSet = true;
-        	}
-	    }
-	    // build heap
-	    for (int i = (_heapSize = _free)/2; i >= 0; i--) {
-		heapify(i);
-	    }
-	    _returnedLast = END;
-	    return resetPosition();
-	}
-	return this;
-    }
-
-    protected void init() {
-        for (int i =0; i < _free; i++) {
-            _heap[i] = null;
-        }
-
-        _heapSize = 0;
-        _free = 0;
-    }
-
-    /* Build a heap in document order. put the smallest node on the top. 
-     * "smallest node" means the node before other nodes in document order
-     */
-    private void heapify(int i) {
-	for (int r, l, smallest;;) {
-	    r = (i + 1) << 1; l = r - 1;
-	    smallest = l < _heapSize 
-		&& _heap[l].isLessThan(_heap[i]) ? l : i;
-	    if (r < _heapSize && _heap[r].isLessThan(_heap[smallest])) {
-		smallest = r;
-	    }
-	    if (smallest != i) {
-		final HeapNode temp = _heap[smallest];
-		_heap[smallest] = _heap[i];
-		_heap[i] = temp;
-		i = smallest;
-	    } else {
-		break;
-            }
-	}
-    }
-
-    public void setMark() {
-	for (int i = 0; i < _free; i++) {
-	    _heap[i].setMark();
-	}
-	_cachedReturnedLast = _returnedLast;    
-	_cachedHeapSize = _heapSize;
-    }
-
-    public void gotoMark() {
-	for (int i = 0; i < _free; i++) {
-	    _heap[i].gotoMark();
-	}
-	// rebuild heap after call last() function. fix for bug 20913
-	for (int i = (_heapSize = _cachedHeapSize)/2; i >= 0; i--) {
-	    heapify(i);
-	}
-        _returnedLast = _cachedReturnedLast;    
-    }
-
-    public DTMAxisIterator reset() {
-	for (int i = 0; i < _free; i++) {
-	    _heap[i].reset();
-	    _heap[i].step();
-	}
-
-	// build heap
-	for (int i = (_heapSize = _free)/2; i >= 0; i--) {
-	    heapify(i);
-	}
-
-	_returnedLast = END;
-	return resetPosition();
-    }
-
-}
+/*
+ * 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.xalan.xsltc.dom;
+
+import org.apache.xalan.xsltc.DOM;
+import org.apache.xalan.xsltc.runtime.BasisLibrary;
+import org.apache.xml.dtm.DTMAxisIterator;
+import org.apache.xml.dtm.ref.DTMAxisIteratorBase;
+
+/**
+ * <p><code>MultiValuedNodeHeapIterator</code> takes a set of multi-valued
+ * heap nodes and produces a merged NodeSet in document order with duplicates
+ * removed.</p>
+ * <p>Each multi-valued heap node (which might be a
+ * {@link org.apache.xml.dtm.DTMAxisIterator}, but that's  not necessary)
+ * generates DTM node handles in document order.  The class
+ * maintains the multi-valued heap nodes in a heap, not surprisingly, sorted by
+ * the next DTM node handle available form the heap node.</p>
+ * <p>After a DTM node is pulled from the heap node that's at the top of the
+ * heap, the heap node is advanced to the next DTM node handle it makes
+ * available, and the heap nature of the heap is restored to ensure the next
+ * DTM node handle pulled is next in document order overall.
+ *
+ * @author Jacek Ambroziak
+ * @author Santiago Pericas-Geertsen
+ */
+public abstract class MultiValuedNodeHeapIterator extends DTMAxisIteratorBase {
+    /** wrapper for NodeIterators to support iterator
+	comparison on the value of their next() method
+    */
+
+    /**
+     * An abstract representation of a set of nodes that will be retrieved in
+     * document order.
+     */
+    public abstract class HeapNode implements Cloneable {
+	protected int _node, _markedNode;
+	protected boolean _isStartSet = false;
+		
+        /**
+         * Advance to the next node represented by this {@link HeapNode}
+         *
+         * @return the next DTM node.
+         */
+	public abstract int step();
+
+
+        /**
+         * Creates a deep copy of this {@link HeapNode}.  The clone is not
+         * reset from the current position of the original.
+         *
+         * @return the cloned heap node
+         */
+	public HeapNode cloneHeapNode() {
+            HeapNode clone;
+
+            try {
+                clone = (HeapNode) super.clone();
+            } catch (CloneNotSupportedException e) {
+                BasisLibrary.runTimeError(BasisLibrary.ITERATOR_CLONE_ERR,
+                                          e.toString());
+                return null;
+            }
+
+	    clone._node = _node;
+	    clone._markedNode = _node;
+
+	    return clone;
+	}
+
+        /**
+         * Remembers the current node for the next call to {@link #gotoMark()}.
+         */
+	public void setMark() {
+	    _markedNode = _node;
+	}
+
+        /**
+         * Restores the current node remembered by {@link #setMark()}.
+         */
+	public void gotoMark() {
+	    _node = _markedNode;
+	}
+
+        /**
+         * Performs a comparison of the two heap nodes
+         *
+         * @param heapNode the heap node against which to compare
+         * @return <code>true</code> if and only if the current node for this
+         *         heap node is before the current node of the argument heap
+         *         node in document order.
+         */
+        public abstract boolean isLessThan(HeapNode heapNode);
+
+        /**
+         * Sets context with respect to which this heap node is evaluated.
+         *
+         * @param node The new context node
+         * @return a {@link HeapNode} which may or may not be the same as
+         *         this <code>HeapNode</code>.
+         */
+        public abstract HeapNode setStartNode(int node);
+
+        /**
+         * Reset the heap node back to its beginning.
+         *
+         * @return a {@link HeapNode} which may or may not be the same as
+         *         this <code>HeapNode</code>.
+         */
+        public abstract HeapNode reset();
+    } // end of HeapNode
+
+    private static final int InitSize = 8;
+  
+    private int        _heapSize = 0;
+    private int        _size = InitSize;
+    private HeapNode[] _heap = new HeapNode[InitSize];
+    private int        _free = 0;
+  
+    // Last node returned by this MultiValuedNodeHeapIterator to the caller of
+    // next; used to prune duplicates
+    private int _returnedLast;
+
+    // cached returned last for use in gotoMark
+    private int _cachedReturnedLast = END;
+
+    // cached heap size for use in gotoMark
+    private int _cachedHeapSize;
+
+
+    public DTMAxisIterator cloneIterator() {
+	_isRestartable = false;
+	final HeapNode[] heapCopy = new HeapNode[_heap.length];
+	try {
+	    MultiValuedNodeHeapIterator clone =
+                    (MultiValuedNodeHeapIterator)super.clone();
+
+            for (int i = 0; i < _free; i++) {
+                heapCopy[i] = _heap[i].cloneHeapNode();
+            }
+	    clone.setRestartable(false);
+	    clone._heap = heapCopy;
+	    return clone.reset();
+	} 
+	catch (CloneNotSupportedException e) {
+	    BasisLibrary.runTimeError(BasisLibrary.ITERATOR_CLONE_ERR,
+				      e.toString());
+	    return null;
+	}
+    }
+    
+    protected void addHeapNode(HeapNode node) {
+	if (_free == _size) {
+	    HeapNode[] newArray = new HeapNode[_size *= 2];
+	    System.arraycopy(_heap, 0, newArray, 0, _free);
+	    _heap = newArray;
+	}
+	_heapSize++;
+	_heap[_free++] = node;
+    }
+  
+    public int next() {
+	while (_heapSize > 0) {
+	    final int smallest = _heap[0]._node;
+	    if (smallest == END) { // iterator _heap[0] is done
+		if (_heapSize > 1) {
+		    // Swap first and last (iterator must be restartable)
+		    final HeapNode temp = _heap[0];
+		    _heap[0] = _heap[--_heapSize];
+		    _heap[_heapSize] = temp;
+		}
+		else {
+		    return END;
+		}
+	    }
+	    else if (smallest == _returnedLast) {	// duplicate
+		_heap[0].step(); // value consumed
+	    }
+	    else {
+		_heap[0].step(); // value consumed
+		heapify(0);
+		return returnNode(_returnedLast = smallest);
+	    }
+	    // fallthrough if not returned above
+	    heapify(0);
+	}
+	return END;
+    }
+  
+    public DTMAxisIterator setStartNode(int node) {
+	if (_isRestartable) {
+	    _startNode = node;
+	    for (int i = 0; i < _free; i++) {
+         	if(!_heap[i]._isStartSet){
+        	   _heap[i].setStartNode(node);
+        	   _heap[i].step();	// to get the first node
+        	   _heap[i]._isStartSet = true;
+        	}
+	    }
+	    // build heap
+	    for (int i = (_heapSize = _free)/2; i >= 0; i--) {
+		heapify(i);
+	    }
+	    _returnedLast = END;
+	    return resetPosition();
+	}
+	return this;
+    }
+
+    protected void init() {
+        for (int i =0; i < _free; i++) {
+            _heap[i] = null;
+        }
+
+        _heapSize = 0;
+        _free = 0;
+    }
+
+    /* Build a heap in document order. put the smallest node on the top. 
+     * "smallest node" means the node before other nodes in document order
+     */
+    private void heapify(int i) {
+	for (int r, l, smallest;;) {
+	    r = (i + 1) << 1; l = r - 1;
+	    smallest = l < _heapSize 
+		&& _heap[l].isLessThan(_heap[i]) ? l : i;
+	    if (r < _heapSize && _heap[r].isLessThan(_heap[smallest])) {
+		smallest = r;
+	    }
+	    if (smallest != i) {
+		final HeapNode temp = _heap[smallest];
+		_heap[smallest] = _heap[i];
+		_heap[i] = temp;
+		i = smallest;
+	    } else {
+		break;
+            }
+	}
+    }
+
+    public void setMark() {
+	for (int i = 0; i < _free; i++) {
+	    _heap[i].setMark();
+	}
+	_cachedReturnedLast = _returnedLast;    
+	_cachedHeapSize = _heapSize;
+    }
+
+    public void gotoMark() {
+	for (int i = 0; i < _free; i++) {
+	    _heap[i].gotoMark();
+	}
+	// rebuild heap after call last() function. fix for bug 20913
+	for (int i = (_heapSize = _cachedHeapSize)/2; i >= 0; i--) {
+	    heapify(i);
+	}
+        _returnedLast = _cachedReturnedLast;    
+    }
+
+    public DTMAxisIterator reset() {
+	for (int i = 0; i < _free; i++) {
+	    _heap[i].reset();
+	    _heap[i].step();
+	}
+
+	// build heap
+	for (int i = (_heapSize = _free)/2; i >= 0; i--) {
+	    heapify(i);
+	}
+
+	_returnedLast = END;
+	return resetPosition();
+    }
+
+}

Propchange: xalan/java/trunk/src/org/apache/xalan/xsltc/dom/MultiValuedNodeHeapIterator.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: xalan/java/trunk/src/org/apache/xalan/xsltc/dom/MultiValuedNodeHeapIterator.java
------------------------------------------------------------------------------
    svn:keywords = Author Date Id Revision

Modified: xalan/java/trunk/src/org/apache/xalan/xsltc/runtime/ErrorMessages_sl.java
URL: http://svn.apache.org/viewvc/xalan/java/trunk/src/org/apache/xalan/xsltc/runtime/ErrorMessages_sl.java?rev=1225426&r1=1225425&r2=1225426&view=diff
==============================================================================
--- xalan/java/trunk/src/org/apache/xalan/xsltc/runtime/ErrorMessages_sl.java (original)
+++ xalan/java/trunk/src/org/apache/xalan/xsltc/runtime/ErrorMessages_sl.java Thu Dec 29 04:13:08 2011
@@ -1,285 +1,285 @@
-/*
- * 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: ErrorMessages_sl.java,v 1.11 2004/12/15 17:35:45 jycli Exp $
- */
-
-package org.apache.xalan.xsltc.runtime;
-
-import java.util.ListResourceBundle;
-
-/**
- * @author Morten Jorgensen
- */
-public class ErrorMessages_sl extends ListResourceBundle {
-
-/*
- * XSLTC run-time error messages.
- *
- * General notes to translators and definitions:
- *
- *   1) XSLTC is the name of the product.  It is an acronym for XML Stylesheet:
- *      Transformations Compiler
- *
- *   2) A stylesheet is a description of how to transform an input XML document
- *      into a resultant output XML document (or HTML document or text)
- *
- *   3) An axis is a particular "dimension" in a tree representation of an XML
- *      document; the nodes in the tree are divided along different axes.
- *      Traversing the "child" axis, for instance, means that the program
- *      would visit each child of a particular node; traversing the "descendant"
- *      axis means that the program would visit the child nodes of a particular
- *      node, their children, and so on until the leaf nodes of the tree are
- *      reached.
- *
- *   4) An iterator is an object that traverses nodes in a tree along a
- *      particular axis, one at a time.
- *
- *   5) An element is a mark-up tag in an XML document; an attribute is a
- *      modifier on the tag.  For example, in <elem attr='val' attr2='val2'>
- *      "elem" is an element name, "attr" and "attr2" are attribute names with
- *      the values "val" and "val2", respectively.
- *
- *   6) A namespace declaration is a special attribute that is used to associate
- *      a prefix with a URI (the namespace).  The meanings of element names and
- *      attribute names that use that prefix are defined with respect to that
- *      namespace.
- *
- *   7) DOM is an acronym for Document Object Model.  It is a tree
- *      representation of an XML document.
- *
- *      SAX is an acronym for the Simple API for XML processing.  It is an API
- *      used inform an XML processor (in this case XSLTC) of the structure and
- *      content of an XML document.
- *
- *      Input to the stylesheet processor can come from an XML parser in the
- *      form of a DOM tree or through the SAX API.
- *
- *   8) DTD is a document type declaration.  It is a way of specifying the
- *      grammar for an XML file, the names and types of elements, attributes,
- *      etc.
- *
- *   9) Translet is an invented term that refers to the class file that contains
- *      the compiled form of a stylesheet.
- */
-
-    // These message should be read from a locale-specific resource bundle
-    /** Get the lookup table for error messages.
-     *
-     * @return The message lookup table.
-     */
-    public Object[][] getContents()
-    {
-      return new Object[][] {
-
-        /*
-         * Note to translators:  the substitution text in the following message
-         * is a class name.  Used for internal errors in the processor.
-         */
-        {BasisLibrary.RUN_TIME_INTERNAL_ERR,
-        "Notranja napaka izvajanja v ''{0}''"},
-
-        /*
-         * Note to translators:  <xsl:copy> is a keyword that should not be
-         * translated.
-         */
-        {BasisLibrary.RUN_TIME_COPY_ERR,
-        "Notranja napaka izvajanja pri izvajanju <xsl:copy>."},
-
-        /*
-         * Note to translators:  The substitution text refers to data types.
-         * The message is displayed if a value in a particular context needs to
-         * be converted to type {1}, but that's not possible for a value of type
-         * {0}.
-         */
-        {BasisLibrary.DATA_CONVERSION_ERR,
-        "Neveljavna pretvorba iz ''{0}'' v ''{1}''."},
-
-        /*
-         * Note to translators:  This message is displayed if the function named
-         * by the substitution text is not a function that is supported.  XSLTC
-         * is the acronym naming the product.
-         */
-        {BasisLibrary.EXTERNAL_FUNC_ERR,
-        "XSLTC ne podpira zunanje funkcije ''{0}''."},
-
-        /*
-         * Note to translators:  This message is displayed if two values are
-         * compared for equality, but the data type of one of the values is
-         * unknown.
-         */
-        {BasisLibrary.EQUALITY_EXPR_ERR,
-        "Neznan tip argumenta v izrazu enakovrednosti."},
-
-        /*
-         * Note to translators:  The substitution text for {0} will be a data
-         * type; the substitution text for {1} will be the name of a function.
-         * This is displayed if an argument of the particular data type is not
-         * permitted for a call to this function.
-         */
-        {BasisLibrary.INVALID_ARGUMENT_ERR,
-        "Neveljavna vrsta argumenta ''{0}'' pri klicu na ''{1}''"},
-
-        /*
-         * Note to translators:  There is way of specifying a format for a
-         * number using a pattern; the processor was unable to format the
-         * particular value using the specified pattern.
-         */
-        {BasisLibrary.FORMAT_NUMBER_ERR,
-        "Pokus nastavitve formata \u0161tevilke ''{0}'' z uporabo vzorca ''{1}''."},
-
-        /*
-         * Note to translators:  The following represents an internal error
-         * situation in XSLTC.  The processor was unable to create a copy of an
-         * iterator.  (See definition of iterator above.)
-         */
-        {BasisLibrary.ITERATOR_CLONE_ERR,
-        "Iteratorja ''{0}'' ni mogo\u010de klonirati."},
-
-        /*
-         * Note to translators:  The following represents an internal error
-         * situation in XSLTC.  The processor attempted to create an iterator
-         * for a particular axis (see definition above) that it does not
-         * support.
-         */
-        {BasisLibrary.AXIS_SUPPORT_ERR,
-        "Iterator za os ''{0}'' ni podprt."},
-
-        /*
-         * Note to translators:  The following represents an internal error
-         * situation in XSLTC.  The processor attempted to create an iterator
-         * for a particular axis (see definition above) that it does not
-         * support.
-         */
-        {BasisLibrary.TYPED_AXIS_SUPPORT_ERR,
-        "Iterator za tipizirano os ''{0}'' ni podprt."},
-
-        /*
-         * Note to translators:  This message is reported if the stylesheet
-         * being processed attempted to construct an XML document with an
-         * attribute in a place other than on an element.  The substitution text
-         * specifies the name of the attribute.
-         */
-        {BasisLibrary.STRAY_ATTRIBUTE_ERR,
-        "Atribut ''{0}'' zunaj elementa."},
-
-        /*
-         * Note to translators:  As with the preceding message, a namespace
-         * declaration has the form of an attribute and is only permitted to
-         * appear on an element.  The substitution text {0} is the namespace
-         * prefix and {1} is the URI that was being used in the erroneous
-         * namespace declaration.
-         */
-        {BasisLibrary.STRAY_NAMESPACE_ERR,
-        "Deklaracija imenskega prostora ''{0}''=''{1}'' je zunaj elementa."},
-
-        /*
-         * Note to translators:  The stylesheet contained a reference to a
-         * namespace prefix that was undefined.  The value of the substitution
-         * text is the name of the prefix.
-         */
-        {BasisLibrary.NAMESPACE_PREFIX_ERR,
-        "Imenski prostor za predpono ''{0}'' ni bil naveden."},
-
-        /*
-         * Note to translators:  The following represents an internal error.
-         * DOMAdapter is a Java class in XSLTC.
-         */
-        {BasisLibrary.DOM_ADAPTER_INIT_ERR,
-        "DOMAdapter ustvarjen z uporabo napa\u010dnega tipa izvornega DOM."},
-
-        /*
-         * Note to translators:  The following message indicates that the XML
-         * parser that is providing input to XSLTC cannot be used because it
-         * does not describe to XSLTC the structure of the input XML document's
-         * DTD.
-         */
-        {BasisLibrary.PARSER_DTD_SUPPORT_ERR,
-        "Uporabljeni raz\u010dlenjevalnik SAX ne obravnava dogodkov deklaracije DTD."},
-
-        /*
-         * Note to translators:  The following message indicates that the XML
-         * parser that is providing input to XSLTC cannot be used because it
-         * does not distinguish between ordinary XML attributes and namespace
-         * declarations.
-         */
-        {BasisLibrary.NAMESPACES_SUPPORT_ERR,
-        "Uporabljeni raz\u010dlenjevalnik SAX ne podpira imenskih prostorov XML."},
-
-        /*
-         * Note to translators:  The substitution text is the URI that was in
-         * error.
-         */
-        {BasisLibrary.CANT_RESOLVE_RELATIVE_URI_ERR,
-        "Ni mogo\u010de razre\u0161iti sklica URI ''{0}''."},
-
-         /*
-         * Note to translators:  The stylesheet contained an element that was
-         * not recognized as part of the XSL syntax.  The substitution text
-         * gives the element name.
-         */
-        {BasisLibrary.UNSUPPORTED_XSL_ERR,
-        "Nepodprt XSL element ''{0}''"},
-
-        /*
-         * Note to translators:  The stylesheet referred to an extension to the
-         * XSL syntax and indicated that it was defined by XSLTC, but XSLTC does
-         * not recognize the particular extension named.  The substitution text
-         * gives the extension name.
-         */
-        {BasisLibrary.UNSUPPORTED_EXT_ERR,
-        "Neprepoznana raz\u0161iritev XSLTC ''{0}''"},
-
-
-        /*
-         * Note to translators:  This error message is produced if the translet
-         * class was compiled using a newer version of XSLTC and deployed for
-         * execution with an older version of XSLTC.  The substitution text is
-         * the name of the translet class.
-         */
-        {BasisLibrary.UNKNOWN_TRANSLET_VERSION_ERR,
-        "Navedeni translet, ''{0}'', je bil ustvarjen z uporabo XSLTC novej\u0161e razli\u010dice, kot je trenutno uporabljana razli\u010dica izvajalnega okolja XSLTC. Slogovno datoteko morate ponovno prevesti ali pa uporabiti novej\u0161o razli\u010dico XSLTC-ja, da bi zagnali ta translet."},
-
-        /*
-         * Note to translators:  An attribute whose effective value is required
-         * to be a "QName" had a value that was incorrect.
-         * 'QName' is an XML syntactic term that must not be translated.  The
-         * substitution text contains the actual value of the attribute.
-         */
-        {BasisLibrary.INVALID_QNAME_ERR,
-        "Atribut, katerega vrednost mora biti QName, je imel vrednost ''{0}''"},
-
-
-        /*
-         * Note to translators:  An attribute whose effective value is required
-         * to be a "NCName" had a value that was incorrect.
-         * 'NCName' is an XML syntactic term that must not be translated.  The
-         * substitution text contains the actual value of the attribute.
-         */
-        {BasisLibrary.INVALID_NCNAME_ERR,
-        "Atribut, katerega vrednost mora biti NCName, je imel vrednost ''{0}''"},
-
-        {BasisLibrary.UNALLOWED_EXTENSION_FUNCTION_ERR,
-        "Uporaba raz\u0161iritvene funkcije ''{0}'' ni dovoljena, ko je funkcija varne obdelave nastavljena na True."},
-
-        {BasisLibrary.UNALLOWED_EXTENSION_ELEMENT_ERR,
-        "Uporaba raz\u0161iritvene elementa ''{0}'' ni dovoljena, ko je funkcija varne obdelave nastavljena na True."},
-    };
-    }
-
-}
+/*
+ * 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.xalan.xsltc.runtime;
+
+import java.util.ListResourceBundle;
+
+/**
+ * @author Morten Jorgensen
+ */
+public class ErrorMessages_sl extends ListResourceBundle {
+
+/*
+ * XSLTC run-time error messages.
+ *
+ * General notes to translators and definitions:
+ *
+ *   1) XSLTC is the name of the product.  It is an acronym for XML Stylesheet:
+ *      Transformations Compiler
+ *
+ *   2) A stylesheet is a description of how to transform an input XML document
+ *      into a resultant output XML document (or HTML document or text)
+ *
+ *   3) An axis is a particular "dimension" in a tree representation of an XML
+ *      document; the nodes in the tree are divided along different axes.
+ *      Traversing the "child" axis, for instance, means that the program
+ *      would visit each child of a particular node; traversing the "descendant"
+ *      axis means that the program would visit the child nodes of a particular
+ *      node, their children, and so on until the leaf nodes of the tree are
+ *      reached.
+ *
+ *   4) An iterator is an object that traverses nodes in a tree along a
+ *      particular axis, one at a time.
+ *
+ *   5) An element is a mark-up tag in an XML document; an attribute is a
+ *      modifier on the tag.  For example, in <elem attr='val' attr2='val2'>
+ *      "elem" is an element name, "attr" and "attr2" are attribute names with
+ *      the values "val" and "val2", respectively.
+ *
+ *   6) A namespace declaration is a special attribute that is used to associate
+ *      a prefix with a URI (the namespace).  The meanings of element names and
+ *      attribute names that use that prefix are defined with respect to that
+ *      namespace.
+ *
+ *   7) DOM is an acronym for Document Object Model.  It is a tree
+ *      representation of an XML document.
+ *
+ *      SAX is an acronym for the Simple API for XML processing.  It is an API
+ *      used inform an XML processor (in this case XSLTC) of the structure and
+ *      content of an XML document.
+ *
+ *      Input to the stylesheet processor can come from an XML parser in the
+ *      form of a DOM tree or through the SAX API.
+ *
+ *   8) DTD is a document type declaration.  It is a way of specifying the
+ *      grammar for an XML file, the names and types of elements, attributes,
+ *      etc.
+ *
+ *   9) Translet is an invented term that refers to the class file that contains
+ *      the compiled form of a stylesheet.
+ */
+
+    // These message should be read from a locale-specific resource bundle
+    /** Get the lookup table for error messages.
+     *
+     * @return The message lookup table.
+     */
+    public Object[][] getContents()
+    {
+      return new Object[][] {
+
+        /*
+         * Note to translators:  the substitution text in the following message
+         * is a class name.  Used for internal errors in the processor.
+         */
+        {BasisLibrary.RUN_TIME_INTERNAL_ERR,
+        "Notranja napaka izvajanja v ''{0}''"},
+
+        /*
+         * Note to translators:  <xsl:copy> is a keyword that should not be
+         * translated.
+         */
+        {BasisLibrary.RUN_TIME_COPY_ERR,
+        "Notranja napaka izvajanja pri izvajanju <xsl:copy>."},
+
+        /*
+         * Note to translators:  The substitution text refers to data types.
+         * The message is displayed if a value in a particular context needs to
+         * be converted to type {1}, but that's not possible for a value of type
+         * {0}.
+         */
+        {BasisLibrary.DATA_CONVERSION_ERR,
+        "Neveljavna pretvorba iz ''{0}'' v ''{1}''."},
+
+        /*
+         * Note to translators:  This message is displayed if the function named
+         * by the substitution text is not a function that is supported.  XSLTC
+         * is the acronym naming the product.
+         */
+        {BasisLibrary.EXTERNAL_FUNC_ERR,
+        "XSLTC ne podpira zunanje funkcije ''{0}''."},
+
+        /*
+         * Note to translators:  This message is displayed if two values are
+         * compared for equality, but the data type of one of the values is
+         * unknown.
+         */
+        {BasisLibrary.EQUALITY_EXPR_ERR,
+        "Neznan tip argumenta v izrazu enakovrednosti."},
+
+        /*
+         * Note to translators:  The substitution text for {0} will be a data
+         * type; the substitution text for {1} will be the name of a function.
+         * This is displayed if an argument of the particular data type is not
+         * permitted for a call to this function.
+         */
+        {BasisLibrary.INVALID_ARGUMENT_ERR,
+        "Neveljavna vrsta argumenta ''{0}'' pri klicu na ''{1}''"},
+
+        /*
+         * Note to translators:  There is way of specifying a format for a
+         * number using a pattern; the processor was unable to format the
+         * particular value using the specified pattern.
+         */
+        {BasisLibrary.FORMAT_NUMBER_ERR,
+        "Pokus nastavitve formata \u0161tevilke ''{0}'' z uporabo vzorca ''{1}''."},
+
+        /*
+         * Note to translators:  The following represents an internal error
+         * situation in XSLTC.  The processor was unable to create a copy of an
+         * iterator.  (See definition of iterator above.)
+         */
+        {BasisLibrary.ITERATOR_CLONE_ERR,
+        "Iteratorja ''{0}'' ni mogo\u010de klonirati."},
+
+        /*
+         * Note to translators:  The following represents an internal error
+         * situation in XSLTC.  The processor attempted to create an iterator
+         * for a particular axis (see definition above) that it does not
+         * support.
+         */
+        {BasisLibrary.AXIS_SUPPORT_ERR,
+        "Iterator za os ''{0}'' ni podprt."},
+
+        /*
+         * Note to translators:  The following represents an internal error
+         * situation in XSLTC.  The processor attempted to create an iterator
+         * for a particular axis (see definition above) that it does not
+         * support.
+         */
+        {BasisLibrary.TYPED_AXIS_SUPPORT_ERR,
+        "Iterator za tipizirano os ''{0}'' ni podprt."},
+
+        /*
+         * Note to translators:  This message is reported if the stylesheet
+         * being processed attempted to construct an XML document with an
+         * attribute in a place other than on an element.  The substitution text
+         * specifies the name of the attribute.
+         */
+        {BasisLibrary.STRAY_ATTRIBUTE_ERR,
+        "Atribut ''{0}'' zunaj elementa."},
+
+        /*
+         * Note to translators:  As with the preceding message, a namespace
+         * declaration has the form of an attribute and is only permitted to
+         * appear on an element.  The substitution text {0} is the namespace
+         * prefix and {1} is the URI that was being used in the erroneous
+         * namespace declaration.
+         */
+        {BasisLibrary.STRAY_NAMESPACE_ERR,
+        "Deklaracija imenskega prostora ''{0}''=''{1}'' je zunaj elementa."},
+
+        /*
+         * Note to translators:  The stylesheet contained a reference to a
+         * namespace prefix that was undefined.  The value of the substitution
+         * text is the name of the prefix.
+         */
+        {BasisLibrary.NAMESPACE_PREFIX_ERR,
+        "Imenski prostor za predpono ''{0}'' ni bil naveden."},
+
+        /*
+         * Note to translators:  The following represents an internal error.
+         * DOMAdapter is a Java class in XSLTC.
+         */
+        {BasisLibrary.DOM_ADAPTER_INIT_ERR,
+        "DOMAdapter ustvarjen z uporabo napa\u010dnega tipa izvornega DOM."},
+
+        /*
+         * Note to translators:  The following message indicates that the XML
+         * parser that is providing input to XSLTC cannot be used because it
+         * does not describe to XSLTC the structure of the input XML document's
+         * DTD.
+         */
+        {BasisLibrary.PARSER_DTD_SUPPORT_ERR,
+        "Uporabljeni raz\u010dlenjevalnik SAX ne obravnava dogodkov deklaracije DTD."},
+
+        /*
+         * Note to translators:  The following message indicates that the XML
+         * parser that is providing input to XSLTC cannot be used because it
+         * does not distinguish between ordinary XML attributes and namespace
+         * declarations.
+         */
+        {BasisLibrary.NAMESPACES_SUPPORT_ERR,
+        "Uporabljeni raz\u010dlenjevalnik SAX ne podpira imenskih prostorov XML."},
+
+        /*
+         * Note to translators:  The substitution text is the URI that was in
+         * error.
+         */
+        {BasisLibrary.CANT_RESOLVE_RELATIVE_URI_ERR,
+        "Ni mogo\u010de razre\u0161iti sklica URI ''{0}''."},
+
+         /*
+         * Note to translators:  The stylesheet contained an element that was
+         * not recognized as part of the XSL syntax.  The substitution text
+         * gives the element name.
+         */
+        {BasisLibrary.UNSUPPORTED_XSL_ERR,
+        "Nepodprt XSL element ''{0}''"},
+
+        /*
+         * Note to translators:  The stylesheet referred to an extension to the
+         * XSL syntax and indicated that it was defined by XSLTC, but XSLTC does
+         * not recognize the particular extension named.  The substitution text
+         * gives the extension name.
+         */
+        {BasisLibrary.UNSUPPORTED_EXT_ERR,
+        "Neprepoznana raz\u0161iritev XSLTC ''{0}''"},
+
+
+        /*
+         * Note to translators:  This error message is produced if the translet
+         * class was compiled using a newer version of XSLTC and deployed for
+         * execution with an older version of XSLTC.  The substitution text is
+         * the name of the translet class.
+         */
+        {BasisLibrary.UNKNOWN_TRANSLET_VERSION_ERR,
+        "Navedeni translet, ''{0}'', je bil ustvarjen z uporabo XSLTC novej\u0161e razli\u010dice, kot je trenutno uporabljana razli\u010dica izvajalnega okolja XSLTC. Slogovno datoteko morate ponovno prevesti ali pa uporabiti novej\u0161o razli\u010dico XSLTC-ja, da bi zagnali ta translet."},
+
+        /*
+         * Note to translators:  An attribute whose effective value is required
+         * to be a "QName" had a value that was incorrect.
+         * 'QName' is an XML syntactic term that must not be translated.  The
+         * substitution text contains the actual value of the attribute.
+         */
+        {BasisLibrary.INVALID_QNAME_ERR,
+        "Atribut, katerega vrednost mora biti QName, je imel vrednost ''{0}''"},
+
+
+        /*
+         * Note to translators:  An attribute whose effective value is required
+         * to be a "NCName" had a value that was incorrect.
+         * 'NCName' is an XML syntactic term that must not be translated.  The
+         * substitution text contains the actual value of the attribute.
+         */
+        {BasisLibrary.INVALID_NCNAME_ERR,
+        "Atribut, katerega vrednost mora biti NCName, je imel vrednost ''{0}''"},
+
+        {BasisLibrary.UNALLOWED_EXTENSION_FUNCTION_ERR,
+        "Uporaba raz\u0161iritvene funkcije ''{0}'' ni dovoljena, ko je funkcija varne obdelave nastavljena na True."},
+
+        {BasisLibrary.UNALLOWED_EXTENSION_ELEMENT_ERR,
+        "Uporaba raz\u0161iritvene elementa ''{0}'' ni dovoljena, ko je funkcija varne obdelave nastavljena na True."},
+    };
+    }
+
+}

Propchange: xalan/java/trunk/src/org/apache/xalan/xsltc/runtime/ErrorMessages_sl.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: xalan/java/trunk/src/org/apache/xalan/xsltc/runtime/ErrorMessages_sl.java
            ('svn:executable' removed)

Propchange: xalan/java/trunk/src/org/apache/xalan/xsltc/runtime/ErrorMessages_sl.java
------------------------------------------------------------------------------
    svn:keywords = Author Date Id Revision



---------------------------------------------------------------------
To unsubscribe, e-mail: xalan-cvs-unsubscribe@xml.apache.org
For additional commands, e-mail: xalan-cvs-help@xml.apache.org