You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@xerces.apache.org by ja...@apache.org on 2006/10/13 23:05:28 UTC

svn commit: r463827 - in /xerces/c/trunk/swig/interfaces: ./ Perl/ framework/ util/

Author: jasons
Date: Fri Oct 13 14:05:26 2006
New Revision: 463827

URL: http://svn.apache.org/viewvc?view=rev&rev=463827
Log:
new interface files

Added:
    xerces/c/trunk/swig/interfaces/Perl/Xerces_IO-extra.pm
    xerces/c/trunk/swig/interfaces/Perl/Xerces_SAX-extra.pm
    xerces/c/trunk/swig/interfaces/Perl/ignore.i
    xerces/c/trunk/swig/interfaces/Perl/sax-callback.i
    xerces/c/trunk/swig/interfaces/Perl/sax-includes.i
    xerces/c/trunk/swig/interfaces/Perl/sax-shadow.i
    xerces/c/trunk/swig/interfaces/Perl/typemaps-io.i
    xerces/c/trunk/swig/interfaces/Xerces_IO.i
    xerces/c/trunk/swig/interfaces/Xerces_SAX.i
    xerces/c/trunk/swig/interfaces/Xerces_common.i
    xerces/c/trunk/swig/interfaces/domxpath-includes.i
      - copied, changed from r442160, xerces/c/trunk/swig/interfaces/dom-includes.i
    xerces/c/trunk/swig/interfaces/framework/XMLAttr.i
    xerces/c/trunk/swig/interfaces/framework/XMLDocumentHandler.i
    xerces/c/trunk/swig/interfaces/init.i
    xerces/c/trunk/swig/interfaces/io-includes.i
    xerces/c/trunk/swig/interfaces/make-xml-exception.i
    xerces/c/trunk/swig/interfaces/operator.i
    xerces/c/trunk/swig/interfaces/output-target.i
    xerces/c/trunk/swig/interfaces/platform.i
    xerces/c/trunk/swig/interfaces/sax-includes.i
    xerces/c/trunk/swig/interfaces/transcoder.i
    xerces/c/trunk/swig/interfaces/typemaps-domnode.i
    xerces/c/trunk/swig/interfaces/typemaps-io.i
    xerces/c/trunk/swig/interfaces/typemaps-sax.i
    xerces/c/trunk/swig/interfaces/typemaps.i
    xerces/c/trunk/swig/interfaces/unicode.i
    xerces/c/trunk/swig/interfaces/util/
    xerces/c/trunk/swig/interfaces/util/PlatformUtils.i
    xerces/c/trunk/swig/interfaces/util/XMLEntityResolver.i
    xerces/c/trunk/swig/interfaces/util/XMLResourceIdentifier.i

Added: xerces/c/trunk/swig/interfaces/Perl/Xerces_IO-extra.pm
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/Perl/Xerces_IO-extra.pm?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/Perl/Xerces_IO-extra.pm (added)
+++ xerces/c/trunk/swig/interfaces/Perl/Xerces_IO-extra.pm Fri Oct 13 14:05:26 2006
@@ -0,0 +1 @@
+package XML::Xerces::IO;

Added: xerces/c/trunk/swig/interfaces/Perl/Xerces_SAX-extra.pm
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/Perl/Xerces_SAX-extra.pm?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/Perl/Xerces_SAX-extra.pm (added)
+++ xerces/c/trunk/swig/interfaces/Perl/Xerces_SAX-extra.pm Fri Oct 13 14:05:26 2006
@@ -0,0 +1,110 @@
+############# Class : XML::Xerces::PerlDefaultHandler ##############
+package XML::Xerces::PerlDefaultHandler;
+use vars qw(@ISA);
+@ISA = qw(XML::Xerces::ContentHandler
+	  XML::Xerces::DocumentHandler);
+sub new {
+  my $class = shift;
+
+  # support copy constructor syntax
+  $class = ref($class) if ref($class);
+
+  return bless {}, $class;
+}
+
+sub startElement {
+  my $self = shift;
+  $self->start_element(@_);
+}
+sub endElement {
+  my $self = shift;
+  $self->end_element(@_);
+}
+sub startPrefixMapping {
+  my $self = shift;
+  $self->start_prefix_mapping(@_);
+}
+sub endPrefixMapping {
+  my $self = shift;
+  $self->end_prefix_mapping(@_);
+}
+sub skippedEntity {
+  my $self = shift;
+  $self->skipped_entity(@_);
+}
+sub startDocument {
+  my $self = shift;
+  $self->start_document();
+}
+sub endDocument {
+  my $self = shift;
+  $self->end_document();
+}
+sub resetDocument {
+  my $self = shift;
+  $self->reset_document();
+}
+sub characters {}
+sub processingInstruction {
+  my $self = shift;
+  $self->processing_instruction(@_);
+}
+sub setDocumentLocator {
+  my $self = shift;
+  $self->set_document_locator(@_);
+}
+sub ignorableWhitespace {
+  my $self = shift;
+  $self->ignorable_whitespace(@_);
+}
+
+#
+# support alternate Perl-friendly syntax
+#
+sub start_element {}
+sub end_element {}
+sub start_prefix_mapping {}
+sub end_prefix_mapping {}
+sub skipped_entity {}
+sub start_document {}
+sub end_document {}
+sub reset_document {}
+sub processing_instruction {}
+sub set_document_locator {}
+sub ignorable_whitespace {}
+
+
+############# Class : XML::Xerces::PerlContentHandler ##############
+package XML::Xerces::PerlContentHandler;
+use vars qw(@ISA);
+@ISA = qw(XML::Xerces::PerlDefaultHandler);
+
+############# Class : XML::Xerces::PerlDocumentHandler ##############
+package XML::Xerces::PerlDocumentHandler;
+use vars qw(@ISA);
+@ISA = qw(XML::Xerces::PerlDefaultHandler);
+
+package XML::Xerces::Attributes;
+sub to_hash {
+  my $self = shift;
+  my %hash;
+  for (my $i=0; $i < $self->getLength(); $i++) {
+    my $qname = $self->getQName($i);
+    $hash{$qname}->{localName} = $self->getLocalName($i);
+    $hash{$qname}->{URI} = $self->getURI($i);
+    $hash{$qname}->{value} = $self->getValue($i);
+    $hash{$qname}->{type} = $self->getType($i);
+  }
+  return %hash;
+}
+
+package XML::Xerces::AttributeList;
+sub to_hash {
+  my $self = shift;
+  my %hash;
+  for (my $i=0;$i<$self->getLength();$i++) {
+    $hash{$self->getName($i)} = $self->getValue($i)
+  }
+  return %hash;
+}
+

Added: xerces/c/trunk/swig/interfaces/Perl/ignore.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/Perl/ignore.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/Perl/ignore.i (added)
+++ xerces/c/trunk/swig/interfaces/Perl/ignore.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,3 @@
+%ignore PerlErrorCallbackHandler::warning(const SAXParseException&);
+%ignore PerlErrorCallbackHandler::error(const SAXParseException&);
+%ignore PerlErrorCallbackHandler::fatalError(const SAXParseException&);

Added: xerces/c/trunk/swig/interfaces/Perl/sax-callback.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/Perl/sax-callback.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/Perl/sax-callback.i (added)
+++ xerces/c/trunk/swig/interfaces/Perl/sax-callback.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,24 @@
+/*
+ * Copyright 2002,2004 The Apache Software Foundation.
+ * 
+ * Licensed 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.
+ */
+
+/*
+ * Perl/sax-callback.i - SAX/SAX2 specific callback handlers
+ *
+ */ 
+
+%import "PerlCallbackHandler.hpp"
+%include "PerlSAXCallbackHandler.hpp"
+

Added: xerces/c/trunk/swig/interfaces/Perl/sax-includes.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/Perl/sax-includes.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/Perl/sax-includes.i (added)
+++ xerces/c/trunk/swig/interfaces/Perl/sax-includes.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,26 @@
+/*
+ * Copyright 2002,2004 The Apache Software Foundation.
+ * 
+ * Licensed 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.
+ */
+
+/*
+ * Perl/includes.i - all Perl #includes needed for Xerces/SAX.cpp
+ *
+ */ 
+
+%{
+
+#include "PerlSAXCallbackHandler.hpp"
+
+%}
\ No newline at end of file

Added: xerces/c/trunk/swig/interfaces/Perl/sax-shadow.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/Perl/sax-shadow.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/Perl/sax-shadow.i (added)
+++ xerces/c/trunk/swig/interfaces/Perl/sax-shadow.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,46 @@
+/*
+ * Copyright 2002,2004 The Apache Software Foundation.
+ * 
+ * Licensed 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.
+ */
+
+/*
+ * Perl/sax-shadow.i - modification of Xerces/SAX.pm code
+ *
+ */ 
+
+/*
+ * Handle Callbacks - until directors work in Perl
+ */
+
+%feature("shadow") XERCES_CPP_NAMESPACE::SAXParser::setDocumentHandler %{
+sub setDocumentHandler {
+    my ($self,$handler) = @_;
+    my $callback = XML::Xerces::PerlSAXCallbackHandler->new($handler);
+    $XML::Xerces::REMEMBER{tied(% {$self})}->{__DOCUMENT_HANDLER} = $callback;
+
+    my @args = ($self,$callback);
+    return XML::Xercesc::SAXParser_setDocumentHandler(@args);
+}
+%}
+
+%feature("shadow") XERCES_CPP_NAMESPACE::SAX2XMLReader::setContentHandler %{
+sub setContentHandler {
+    my ($self,$handler) = @_;
+    my $callback = XML::Xerces::PerlSAXCallbackHandler->new($handler);
+    $XML::Xerces::REMEMBER{tied(% {$self})}->{__CONTENT_HANDLER} = $callback;
+
+    my @args = ($self,$callback);
+    return XML::Xercesc::SAX2XMLReader_setContentHandler(@args);
+}
+%}

Added: xerces/c/trunk/swig/interfaces/Perl/typemaps-io.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/Perl/typemaps-io.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/Perl/typemaps-io.i (added)
+++ xerces/c/trunk/swig/interfaces/Perl/typemaps-io.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,19 @@
+// XMLByte arrays are just unisgned char*'s
+// force loading of FromCharPtr fragment - needed for DOM
+%typemap(out, noblock=1, fragment="SWIG_FromCharPtr") const XMLByte* getRawBuffer() {
+  %set_output(SWIG_FromCharPtr((char*)$1));
+}
+
+%typemap(in) (const XMLByte* const srcDocBytes, 
+	      unsigned int byteCount) {
+  if (SvPOK($input)||SvIOK($input)||SvNOK($input)) {
+    STRLEN len;
+    XMLByte *xmlbytes = (XMLByte *)SvPV($input, len);
+    $2 = len;
+    $1 = new XMLByte[len];
+    memcpy($1, xmlbytes, len);
+  } else {
+    SWIG_croak("Type error in argument 2 of $symname, Expected perl-string.");
+  }
+}
+

Added: xerces/c/trunk/swig/interfaces/Xerces_IO.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/Xerces_IO.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/Xerces_IO.i (added)
+++ xerces/c/trunk/swig/interfaces/Xerces_IO.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,113 @@
+/*
+ * Copyright 2002,2004 The Apache Software Foundation.
+ * 
+ * Licensed 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.
+ */
+
+/* 
+ * All DOM classes and their related SWIG alterations go in this interface file
+ */
+
+/*
+ * Modulename - this *must* be in double quotes to properly handle
+ *   the namespace
+ */
+#ifdef SWIGPERL
+%module(package="XML::Xerces") "XML::Xerces::IO"
+#endif
+#ifdef SWIGXML
+%module(package="XML::Xerces") "XML::Xerces::IO"
+#endif
+
+/*
+ * All the module-specific includes
+ *
+ */
+%include "io-includes.i"
+
+/*
+ * After this we will be under the Xerces namespace
+ *
+ */
+
+%{
+
+XERCES_CPP_NAMESPACE_USE
+
+%}
+
+/*
+ * Import the common macros
+ */
+%include "Xerces_common.i"
+
+/*
+ * Import the module-specific typemaps
+ */
+
+%include "typemaps-io.i"
+
+/*
+ * Import the language specific macros
+ */
+
+#ifdef SWIGPERL
+%include "Perl/typemaps-io.i"
+#endif
+
+/*
+ * Import the type information from other modules
+ */
+
+%import "Xerces.i"
+
+/*
+ * Define exception handlers
+ *
+ */
+
+%exception {
+    try 
+    {
+        $action
+    } 
+    CATCH_XML_EXCEPTION
+}
+
+
+/*
+ * Module specific classes
+ *
+ */
+
+/*
+ * InputSource
+ */
+
+%include "input-source.i"
+
+
+/*
+ * OutputTarget
+ */
+
+%include "output-target.i"
+
+#ifdef SWIGPERL
+
+/* 
+ * Include extra verbatim Perl code
+ */
+%pragma(perl5) include="../../interfaces/Perl/Xerces_IO-extra.pm"
+
+#endif

Added: xerces/c/trunk/swig/interfaces/Xerces_SAX.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/Xerces_SAX.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/Xerces_SAX.i (added)
+++ xerces/c/trunk/swig/interfaces/Xerces_SAX.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,185 @@
+/*
+ * Copyright 2002,2004 The Apache Software Foundation.
+ * 
+ * Licensed 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.
+ */
+
+/* 
+ * All SAX/SAX2 classes and their related SWIG alterations go in this interface file
+ */
+
+/*
+ * Modulename - this *must* be in double quotes to properly handle
+ *   the namespace
+ */
+#ifdef SWIGPERL
+%module(package="XML::Xerces") "XML::Xerces::SAX"
+#endif
+
+/*
+ * All the module-specific includes
+ *
+ */
+%include "io-includes.i"
+%include "sax-includes.i"
+
+/*
+ * After this we will be under the Xerces namespace
+ *
+ */
+
+%{
+
+XERCES_CPP_NAMESPACE_USE
+
+void
+makeSAXNotRecognizedException(const SAXNotRecognizedException& e){
+    SV *error = ERRSV;
+    SWIG_MakePtr(error, (void *) new SAXNotRecognizedException(e), SWIGTYPE_p_XERCES_CPP_NAMESPACE__SAXNotRecognizedException, SWIG_SHADOW|0);
+}
+
+void
+makeSAXNotSupportedException(const SAXNotSupportedException& e){
+    SV *error = ERRSV;
+    SWIG_MakePtr(error, (void *) new SAXNotSupportedException(e), SWIGTYPE_p_XERCES_CPP_NAMESPACE__SAXNotSupportedException, SWIG_SHADOW|0);
+}
+
+%}
+
+/*
+ * Import the common macros
+ */
+%include "Xerces_common.i"
+
+/*
+ * Import the language specific macros
+ */
+
+#ifdef SWIGPERL
+%include "Perl/shadow.i"
+%include "Perl/sax-shadow.i"
+%include "Perl/sax-includes.i"
+#endif
+
+/*
+ * Import the module-specific typemaps
+ */
+
+%include "typemaps-sax.i"
+
+/*
+ * Import the type information from other modules
+ */
+
+%import "Xerces.i"
+%import "Xerces_IO.i"
+
+/*
+ * Have the scripting language manage the memory for objects created
+ * in factory methods SWIG will automatically handle objects created
+ * in constructors but it must be told what methods are factory
+ * methods
+ */
+%newobject createXMLReader;
+
+/*
+ * Define exception handlers
+ *
+ */
+
+%exception {
+    try 
+    {
+        $action
+    } 
+    CATCH_XML_EXCEPTION
+}
+
+/*
+ * SAX1
+ */
+
+%include "SAX.i"
+
+/*
+ * SAX2
+ */
+
+%include "SAX2.i"
+
+%include "xercesc/sax/Parser.hpp"
+%include "xercesc/parsers/SAXParser.hpp"
+
+/*
+ * the SAX2XMLReader methods gets a special exception handler
+ *    'goto fail' must be called - either explicitly, or via SWIG_croak()
+ *    to ensure that any variable cleanup is done - to avoid memory leaks.
+ *    We make this a macro to be similar to the other exception handlers.
+ */
+%{
+#define CATCH_SAX_EXCEPTION                           \
+    catch (const XMLException& e)                     \
+        {                                             \
+	    makeXMLException(e);                      \
+            goto fail;                                \
+        }                                             \
+    catch (const SAXNotSupportedException& e)         \
+	{                                             \
+	    makeSAXNotSupportedException(e);          \
+            goto fail;                                \
+	}                                             \
+    catch (const SAXNotRecognizedException& e)        \
+	{                                             \
+	    makeSAXNotRecognizedException(e);         \
+            goto fail;                                \
+	}                                             \
+    catch (...)                                       \
+        {                                             \
+            SWIG_croak("Handling Unknown exception"); \
+            goto fail;                                \
+        }
+%}
+
+%define SAXEXCEPTION(method)
+%exception method {
+    try {
+        $action
+    } 
+    CATCH_SAX_EXCEPTION
+}
+%enddef
+
+SAXEXCEPTION(XERCES_CPP_NAMESPACE::SAX2XMLReader::getFeature)
+SAXEXCEPTION(XERCES_CPP_NAMESPACE::SAX2XMLReader::setFeature)
+SAXEXCEPTION(XERCES_CPP_NAMESPACE::SAX2XMLReader::setProperty)
+SAXEXCEPTION(XERCES_CPP_NAMESPACE::SAX2XMLReader::getProperty)
+SAXEXCEPTION(XERCES_CPP_NAMESPACE::SAX2XMLReader::parse)
+
+%include "xercesc/sax2/SAX2XMLReader.hpp"
+%include "xercesc/sax2/XMLReaderFactory.hpp"
+
+#ifdef SWIGPERL
+
+/* 
+ * Callbacks - this needs to be at the very end
+ *   so that SWIG can wrap the superclass methods properly
+ */
+
+%include "Perl/sax-callback.i"
+
+/* 
+ * Include extra verbatim Perl code
+ */
+%pragma(perl5) include="../../interfaces/Perl/Xerces_SAX-extra.pm"
+
+#endif

Added: xerces/c/trunk/swig/interfaces/Xerces_common.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/Xerces_common.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/Xerces_common.i (added)
+++ xerces/c/trunk/swig/interfaces/Xerces_common.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,70 @@
+/*
+ * Copyright 2002,2004 The Apache Software Foundation.
+ * 
+ * Licensed 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.
+ */
+
+/* 
+ * The interface files that are common to all the Xerces top-level modules
+ */
+
+%include "includes.i"
+
+/*
+ * Platform and compiler specific items
+ */
+
+%include "platform.i"
+
+/*
+ * Import the language specific macros - not namespace dependent
+ *   we place these first so that they can define any master
+ *   macros needed by the language-independent interface files
+ */
+
+#ifdef SWIGPERL
+%include "Perl/shadow.i"
+%include "Perl/ignore.i"
+%include "Perl/errors.i"
+%include "Perl/defines.i"
+%include "Perl/includes.i"
+#endif
+
+/* 
+ * External objects
+ */
+%include "transcoder.i"
+%include "make-xml-exception.i"
+
+/* 
+ * Common typemaps
+ */
+%include "typemaps.i"
+
+/* 
+ * Include extra verbatim C code in the initialization function
+ */
+%include "init.i"
+
+/* 
+ * The general %ignore directives
+ */
+
+%include "ignore.i"
+
+/*
+ * Operator support
+ */
+
+%include "operator.i"
+

Copied: xerces/c/trunk/swig/interfaces/domxpath-includes.i (from r442160, xerces/c/trunk/swig/interfaces/dom-includes.i)
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/domxpath-includes.i?view=diff&rev=463827&p1=xerces/c/trunk/swig/interfaces/dom-includes.i&r1=442160&p2=xerces/c/trunk/swig/interfaces/domxpath-includes.i&r2=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/dom-includes.i (original)
+++ xerces/c/trunk/swig/interfaces/domxpath-includes.i Fri Oct 13 14:05:26 2006
@@ -16,15 +16,5 @@
 
 %{
 #include "xercesc/dom/DOM.hpp"
-#include "xercesc/util/XMLException.hpp"
-#include "xercesc/framework/Wrapper4InputSource.hpp"
-#include "xercesc/framework/Wrapper4DOMLSInput.hpp"
-#include "xercesc/parsers/AbstractDOMParser.hpp"
-#include "xercesc/parsers/XercesDOMParser.hpp"
-#include "xercesc/framework/MemBufFormatTarget.hpp"
-#include "xercesc/framework/LocalFileFormatTarget.hpp"
-#include "xercesc/framework/StdOutFormatTarget.hpp"
-#include "xercesc/util/XMLUni.hpp"
-
 %}
 

Added: xerces/c/trunk/swig/interfaces/framework/XMLAttr.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/framework/XMLAttr.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/framework/XMLAttr.i (added)
+++ xerces/c/trunk/swig/interfaces/framework/XMLAttr.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1 @@
+%include "xercesc/framework/XMLAttr.hpp"
\ No newline at end of file

Added: xerces/c/trunk/swig/interfaces/framework/XMLDocumentHandler.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/framework/XMLDocumentHandler.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/framework/XMLDocumentHandler.i (added)
+++ xerces/c/trunk/swig/interfaces/framework/XMLDocumentHandler.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,26 @@
+%import "xercesc/util/BaseRefVectorOf.hpp";
+%import "xercesc/util/RefVectorOf.hpp";
+namespace XERCES_CPP_NAMESPACE {
+  %template(BaseXMLAttrVector)  BaseRefVectorOf<XMLAttr>;
+  %template(XMLAttrVector)  RefVectorOf<XMLAttr>;
+}
+%include "framework/XMLAttr.i"
+// advanced document handler interface
+%include "xercesc/framework/XMLDocumentHandler.hpp"
+
+// Now, we ignore these methods (without class names)!!!
+// Many of the parser implement these methods, and they are not
+// useful as part of the parser API - i.e. an application will not
+// invoke these methods directly on the parser object
+%ignore docCharacters;
+%ignore docComment;
+%ignore docPI;
+%ignore endDocument;
+%ignore endElement;
+%ignore endEntityReference;
+%ignore ignorableWhitespace;
+%ignore resetDocument;
+%ignore startDocument;
+%ignore startElement;
+%ignore startEntityReference;
+%ignore XMLDecl;

Added: xerces/c/trunk/swig/interfaces/init.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/init.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/init.i (added)
+++ xerces/c/trunk/swig/interfaces/init.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,33 @@
+/*
+ * Copyright 2002,2004 The Apache Software Foundation.
+ * 
+ * Licensed 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.
+ */
+
+/* 
+ * Include extra verbatim C code in the initialization function
+ */
+%init %{
+    // we create the global transcoder for UTF-8 to UTF-16
+    // must initialize the Xerces-C transcoding service
+    XMLPlatformUtils::Initialize();
+    UTF8_TRANSCODER = Transcoder::getInstance();
+    if (! UTF8_TRANSCODER) {
+	croak("ERROR: XML::Xerces: INIT: Could not create UTF-8 transcoder");
+    }
+
+    XML_EXCEPTION_HANDLER = XMLExceptionHandler::getInstance();
+    if (! XML_EXCEPTION_HANDLER) {
+	croak("ERROR: XML::Xerces: INIT: Could not create XMLExceptionHandler");
+    }
+%}

Added: xerces/c/trunk/swig/interfaces/io-includes.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/io-includes.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/io-includes.i (added)
+++ xerces/c/trunk/swig/interfaces/io-includes.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,15 @@
+%{ 
+
+#include "xercesc/sax/InputSource.hpp"
+
+#include "xercesc/framework/LocalFileInputSource.hpp"
+#include "xercesc/framework/MemBufInputSource.hpp"
+#include "xercesc/framework/StdInInputSource.hpp"
+#include "xercesc/framework/URLInputSource.hpp"
+
+#include "xercesc/framework/XMLFormatter.hpp"
+#include "xercesc/framework/MemBufFormatTarget.hpp"
+#include "xercesc/framework/LocalFileFormatTarget.hpp"
+#include "xercesc/framework/StdOutFormatTarget.hpp"
+
+%}
\ No newline at end of file

Added: xerces/c/trunk/swig/interfaces/make-xml-exception.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/make-xml-exception.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/make-xml-exception.i (added)
+++ xerces/c/trunk/swig/interfaces/make-xml-exception.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,48 @@
+/*
+ * Copyright 2002,2004 The Apache Software Foundation.
+ * 
+ * Licensed 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.
+ */
+
+%{
+
+static XMLExceptionHandler* XML_EXCEPTION_HANDLER  = NULL;
+
+void
+makeXMLException(const XMLException& e){
+    SV *error = ERRSV;
+    SWIG_MakePtr(error, (void *) XML_EXCEPTION_HANDLER->copyXMLException(e), SWIGTYPE_p_XERCES_CPP_NAMESPACE__XMLException, SWIG_SHADOW|0);
+}
+
+/*
+ * The generic exception handler
+ *    'goto fail' must be called - either explicitly, or via SWIG_croak()
+ *    to ensure that any variable cleanup is done - to avoid memory leaks.
+ *    By making these macros, it reduces the code *file* size dramatically
+ *    (but doesn't reduce the compiled file size at all...)
+ */
+
+#define CATCH_XML_EXCEPTION         \
+    catch (const XMLException& e)   \
+    {                               \
+        makeXMLException(e);        \
+	goto fail;                  \
+    }                               \
+    catch (...)                     \
+    {                               \
+        SWIG_croak("Handling Unknown exception"); \
+        goto fail;                  \
+    }
+
+%}
+

Added: xerces/c/trunk/swig/interfaces/operator.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/operator.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/operator.i (added)
+++ xerces/c/trunk/swig/interfaces/operator.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,10 @@
+// Operators we don't want to wrap
+%ignore operator =;
+%ignore operator new;
+%ignore operator delete;
+%ignore operator <<;
+
+// Operators we do want
+%rename(operator_equal_to) operator==;
+%rename(operator_not_equal_to) operator!=;
+

Added: xerces/c/trunk/swig/interfaces/output-target.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/output-target.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/output-target.i (added)
+++ xerces/c/trunk/swig/interfaces/output-target.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,4 @@
+%include "framework/XMLFormatter.i"
+%include "framework/StdOutFormatTarget.i"
+%include "framework/LocalFileFormatTarget.i"
+%include "framework/MemBufFormatTarget.i"
\ No newline at end of file

Added: xerces/c/trunk/swig/interfaces/platform.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/platform.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/platform.i (added)
+++ xerces/c/trunk/swig/interfaces/platform.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,12 @@
+/*****************************/
+/*                           */
+/*  Platforms and Compilers  */
+/*                           */
+/*****************************/
+
+// we seem to need these defs loaded before parsing XercesDefs.hpp
+// as of Xerces-3.0
+%import "xercesc/util/Xerces_autoconf_config.hpp" // for XMLSize_t and namespaces
+
+%import "xercesc/util/XercesDefs.hpp"
+

Added: xerces/c/trunk/swig/interfaces/sax-includes.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/sax-includes.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/sax-includes.i (added)
+++ xerces/c/trunk/swig/interfaces/sax-includes.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,34 @@
+/*
+ * Copyright 2002,2004 The Apache Software Foundation.
+ * 
+ * Licensed 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.
+ */
+
+/*
+ * includes.i - all the #includes needed for Xerces/SAX.cpp
+ */
+
+%{
+
+#include "xercesc/sax/Locator.hpp"
+#include "xercesc/sax/HandlerBase.hpp"
+#include "xercesc/parsers/SAXParser.hpp"
+
+#include "xercesc/sax2/Attributes.hpp"
+#include "xercesc/sax2/ContentHandler.hpp"
+#include "xercesc/sax2/LexicalHandler.hpp"
+#include "xercesc/sax2/DeclHandler.hpp"
+#include "xercesc/sax2/SAX2XMLReader.hpp"
+#include "xercesc/sax2/XMLReaderFactory.hpp"
+
+%}
\ No newline at end of file

Added: xerces/c/trunk/swig/interfaces/transcoder.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/transcoder.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/transcoder.i (added)
+++ xerces/c/trunk/swig/interfaces/transcoder.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,24 @@
+/*
+ * Copyright 2002,2004 The Apache Software Foundation.
+ * 
+ * Licensed 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.
+ */
+
+%{
+
+// we initialize the static UTF-8 transcoding info
+// these are used by the typemaps to convert between
+// Xerces internal UTF-16 and the scripting language format
+static Transcoder* UTF8_TRANSCODER  = NULL;
+
+%}
\ No newline at end of file

Added: xerces/c/trunk/swig/interfaces/typemaps-domnode.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/typemaps-domnode.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/typemaps-domnode.i (added)
+++ xerces/c/trunk/swig/interfaces/typemaps-domnode.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,55 @@
+/*
+ * DOM_Node*
+ */
+
+%typemap(out) XERCES_CPP_NAMESPACE::DOMNode * = SWIGTYPE *DYNAMIC;
+
+DYNAMIC_CAST(SWIGTYPE_p_XERCES_CPP_NAMESPACE__DOMNode, DOMNode_dynamic_cast);
+
+%{
+static swig_type_info *
+DOMNode_dynamic_cast(void **ptr) {
+   DOMNode **nptr = (DOMNode **) ptr;
+   if (*nptr == NULL) {
+       return NULL;
+   }
+   short int type = (*nptr)->getNodeType();
+   if (type == DOMNode::TEXT_NODE) {
+      return SWIGTYPE_p_XERCES_CPP_NAMESPACE__DOMText;
+   }
+   if (type == DOMNode::PROCESSING_INSTRUCTION_NODE) {
+      return SWIGTYPE_p_XERCES_CPP_NAMESPACE__DOMProcessingInstruction;
+   }
+   if (type == DOMNode::DOCUMENT_NODE) {
+      return SWIGTYPE_p_XERCES_CPP_NAMESPACE__DOMDocument;
+   }
+   if (type == DOMNode::ELEMENT_NODE) {
+      return SWIGTYPE_p_XERCES_CPP_NAMESPACE__DOMElement;
+   }
+   if (type == DOMNode::ENTITY_REFERENCE_NODE) {
+      return SWIGTYPE_p_XERCES_CPP_NAMESPACE__DOMEntityReference;
+   }
+   if (type == DOMNode::CDATA_SECTION_NODE) {
+      return SWIGTYPE_p_XERCES_CPP_NAMESPACE__DOMCDATASection;
+   }
+   if (type == DOMNode::CDATA_SECTION_NODE) {
+      return SWIGTYPE_p_XERCES_CPP_NAMESPACE__DOMCDATASection;
+   }
+   if (type == DOMNode::COMMENT_NODE) {
+      return SWIGTYPE_p_XERCES_CPP_NAMESPACE__DOMComment;
+   }
+   if (type == DOMNode::DOCUMENT_TYPE_NODE) {
+      return SWIGTYPE_p_XERCES_CPP_NAMESPACE__DOMDocumentType;
+   }
+   if (type == DOMNode::ENTITY_NODE) {
+      return SWIGTYPE_p_XERCES_CPP_NAMESPACE__DOMEntity;
+   }
+   if (type == DOMNode::ATTRIBUTE_NODE) {
+      return SWIGTYPE_p_XERCES_CPP_NAMESPACE__DOMAttr;
+   }
+   if (type == DOMNode::NOTATION_NODE) {
+      return SWIGTYPE_p_XERCES_CPP_NAMESPACE__DOMNotation;
+   }
+   return NULL;
+}
+%}

Added: xerces/c/trunk/swig/interfaces/typemaps-io.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/typemaps-io.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/typemaps-io.i (added)
+++ xerces/c/trunk/swig/interfaces/typemaps-io.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,32 @@
+/*
+ * Copyright 2002,2004 The Apache Software Foundation.
+ * 
+ * Licensed 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.
+ */
+
+/*
+ *  MemBufInputSource::MemBufInputSource()
+ * 
+ */
+
+// %typemap(in,numinputs=0) (unsigned int byteCount) "$1 = 0;" 
+
+/*
+ * These arguments are used to indicate that Xerces-C should
+ *    adopt a resource being passed as an argument. We should
+ *    *always* tell Xerces-C to adopt.
+ */
+%typemap(in,numinputs=0) const bool adoptFlag "$1 = true;"   // for Wrapper4InputSource
+                                                             // and Wrapper4DOMInputSource
+%typemap(in,numinputs=0) const bool adoptBuffer "$1 = true;" // for MemBufInputSource
+

Added: xerces/c/trunk/swig/interfaces/typemaps-sax.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/typemaps-sax.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/typemaps-sax.i (added)
+++ xerces/c/trunk/swig/interfaces/typemaps-sax.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,27 @@
+/*
+ * Copyright 2002,2004 The Apache Software Foundation.
+ * 
+ * Licensed 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.
+ */
+
+// SAX2XMLReader::setProperty() should refuse the option to set the
+// security manager
+%extend XERCES_CPP_NAMESPACE::SAX2XMLReader {
+%typemap(check) (const XMLCh* const name, void* value) {
+  if (XMLString::compareIStringASCII($1, XMLUni::fgXercesSecurityManager) == 0) {
+    makeSAXNotSupportedException(SAXNotSupportedException("Setting security manager not supported"));
+    goto fail;
+  }
+}
+}
+

Added: xerces/c/trunk/swig/interfaces/typemaps.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/typemaps.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/typemaps.i (added)
+++ xerces/c/trunk/swig/interfaces/typemaps.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,24 @@
+/*
+ * Copyright 2002,2004 The Apache Software Foundation.
+ * 
+ * Licensed 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.
+ */
+
+#ifdef SWIGPERL
+%include "Perl/typemaps.i"
+%include "Perl/typemaps-xmlch.i"
+#endif
+
+%include "typemaps-xmlch.i"
+%include "typemaps-general.i"
+

Added: xerces/c/trunk/swig/interfaces/unicode.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/unicode.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/unicode.i (added)
+++ xerces/c/trunk/swig/interfaces/unicode.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,11 @@
+// not needed - these defined individual characters
+// %include "xercesc/util/XMLUniDefs.hpp"
+
+// general string constants
+%include "xercesc/util/XMLUni.hpp"
+
+// constants for schema support
+%include "xercesc/validators/schema/SchemaSymbols.hpp"
+
+// constants for PSVI
+%include "PSVIWriter/PSVIUni.hpp"
\ No newline at end of file

Added: xerces/c/trunk/swig/interfaces/util/PlatformUtils.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/util/PlatformUtils.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/util/PlatformUtils.i (added)
+++ xerces/c/trunk/swig/interfaces/util/PlatformUtils.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,64 @@
+// both of these static variables cause trouble
+// the transcoding service is only useful to C++ anyway.
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::fgTransService;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::fgNetAccessor;
+
+// these are other static variables that are useless to Perl
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::fgUserPanicHandler;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::fgDefaultPanicHandler;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::fgMemoryManager;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::fgDefaulPanicHandler;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::fgArrayMemoryManager;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::fgAtomicMutex;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::fgFileMgr;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::fgMutexMgr;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::fgAtomicOpMgr;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::fgXMLChBigEndian;
+
+// these are methods that are useless in Perl
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::curFilePos;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::closeFile;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::fileSize;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::openFile;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::openFileToWrite;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::openStdInHandle;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::readFileBuffer;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::writeBufferToFile;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::resetFile;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::getFullPath;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::getCurrentDirectory;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::isAnySlash;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::removeDotSlash;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::removeDotDotSlash;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::isRelative;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::weavePaths;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::getCurrentMillis;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::closeMutex;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::lockMutex;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::makeMutex;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::unlockMutex;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::loadMsgSet;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::compareAndSwap;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::atomicIncrement;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::atomicDecrement;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::recognizeNEL;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::isNELRecognized;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::strictIANAEncoding;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::isStrictIANAEncoding;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::alignPointerForNewBlockAllocation;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::makeFileMgr;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::makeMutexMgr;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::makeAtomicOpMgr;
+%ignore XERCES_CPP_NAMESPACE::XMLPlatformUtils::panic;
+
+// changing the locale and the NLS home is probably useful
+// but changing the panic manager and memory manager is not
+%ignore Initialize(const char*          const
+                         , const char*          const
+                         ,       PanicHandler*  const
+                         ,       MemoryManager* const);
+%ignore Initialize(const char*          const
+                         , const char*          const
+                         ,       PanicHandler*  const);
+
+%include "xercesc/util/PlatformUtils.hpp"

Added: xerces/c/trunk/swig/interfaces/util/XMLEntityResolver.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/util/XMLEntityResolver.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/util/XMLEntityResolver.i (added)
+++ xerces/c/trunk/swig/interfaces/util/XMLEntityResolver.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1,4 @@
+%import "xercesc/sax/EntityResolver.hpp"
+
+%include "xercesc/util/XMLResourceIdentifier.hpp"
+%include "xercesc/util/XMLEntityResolver.hpp"
\ No newline at end of file

Added: xerces/c/trunk/swig/interfaces/util/XMLResourceIdentifier.i
URL: http://svn.apache.org/viewvc/xerces/c/trunk/swig/interfaces/util/XMLResourceIdentifier.i?view=auto&rev=463827
==============================================================================
--- xerces/c/trunk/swig/interfaces/util/XMLResourceIdentifier.i (added)
+++ xerces/c/trunk/swig/interfaces/util/XMLResourceIdentifier.i Fri Oct 13 14:05:26 2006
@@ -0,0 +1 @@
+%include "xercesc/util/XMLResourceIdentifier.hpp"
\ No newline at end of file



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