Update the dependencies to use project version
[aai/sparky-be.git] / src / main / java / org / onap / aai / sparky / synchronizer / SyncHelper.java
1 /**
2  * ============LICENSE_START=======================================================
3  * org.onap.aai
4  * ================================================================================
5  * Copyright © 2017 AT&T Intellectual Property. All rights reserved.
6  * Copyright © 2017 Amdocs
7  * ================================================================================
8  * Licensed under the Apache License, Version 2.0 (the "License");
9  * you may not use this file except in compliance with the License.
10  * You may obtain a copy of the License at
11  *
12  *       http://www.apache.org/licenses/LICENSE-2.0
13  *
14  * Unless required by applicable law or agreed to in writing, software
15  * distributed under the License is distributed on an "AS IS" BASIS,
16  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
17  * See the License for the specific language governing permissions and
18  * limitations under the License.
19  * ============LICENSE_END=========================================================
20  *
21  * ECOMP is a trademark and service mark of AT&T Intellectual Property.
22  */
23 package org.onap.aai.sparky.synchronizer;
24
25 import com.google.common.util.concurrent.ThreadFactoryBuilder;
26
27 import java.lang.Thread.UncaughtExceptionHandler;
28 import java.text.SimpleDateFormat;
29 import java.util.ArrayList;
30 import java.util.Calendar;
31 import java.util.List;
32 import java.util.Map;
33 import java.util.TimeZone;
34 import java.util.concurrent.Executors;
35 import java.util.concurrent.ScheduledExecutorService;
36 import java.util.concurrent.ThreadFactory;
37 import java.util.concurrent.TimeUnit;
38 import java.util.concurrent.atomic.AtomicLong;
39
40 import org.onap.aai.sparky.config.oxm.OxmEntityDescriptor;
41 import org.onap.aai.sparky.config.oxm.OxmModelLoader;
42 import org.onap.aai.sparky.dal.aai.ActiveInventoryAdapter;
43 import org.onap.aai.sparky.dal.aai.config.ActiveInventoryConfig;
44 import org.onap.aai.sparky.dal.aai.config.ActiveInventoryRestConfig;
45 import org.onap.aai.sparky.dal.cache.EntityCache;
46 import org.onap.aai.sparky.dal.cache.InMemoryEntityCache;
47 import org.onap.aai.sparky.dal.cache.PersistentEntityCache;
48 import org.onap.aai.sparky.dal.elasticsearch.ElasticSearchAdapter;
49 import org.onap.aai.sparky.dal.elasticsearch.config.ElasticSearchConfig;
50 import org.onap.aai.sparky.dal.rest.RestClientBuilder;
51 import org.onap.aai.sparky.dal.rest.RestfulDataAccessor;
52 import org.onap.aai.sparky.logging.AaiUiMsgs;
53 import org.onap.aai.sparky.synchronizer.SyncController.SyncActions;
54 import org.onap.aai.sparky.synchronizer.config.SynchronizerConfiguration;
55 import org.onap.aai.sparky.synchronizer.config.SynchronizerConstants;
56 import org.onap.aai.sparky.synchronizer.enumeration.SynchronizerState;
57 import org.onap.aai.sparky.util.ErrorUtil;
58 import org.onap.aai.sparky.viewandinspect.config.TierSupportUiConstants;
59 import org.onap.aai.cl.api.Logger;
60 import org.onap.aai.cl.eelf.LoggerFactory;
61 import org.slf4j.MDC;
62
63 /**
64  * The Class SyncHelper.
65  *
66  * @author davea.
67  */
68 public class SyncHelper {
69
70   private final Logger LOG = LoggerFactory.getInstance().getLogger(SyncHelper.class);
71   private SyncController syncController = null;
72   private SyncController entityCounterHistorySummarizer = null;
73
74   private ScheduledExecutorService oneShotExecutor = Executors.newSingleThreadScheduledExecutor();
75   private ScheduledExecutorService periodicExecutor = null;
76   private ScheduledExecutorService historicalExecutor =
77       Executors.newSingleThreadScheduledExecutor();
78
79   private SynchronizerConfiguration syncConfig;
80   private ElasticSearchConfig esConfig;
81   private OxmModelLoader oxmModelLoader;
82
83   private Boolean initialSyncRunning = false;
84   private SimpleDateFormat sdf = new SimpleDateFormat("yyyy-MM-dd HH:mm:ss z");
85   private AtomicLong timeNextSync = new AtomicLong();
86   Map<String, String> contextMap;
87
88   /**
89    * The Class SyncTask.
90    */
91   private class SyncTask implements Runnable {
92
93     private boolean isInitialSync;
94
95     public boolean isInitialSync() {
96       return isInitialSync;
97     }
98
99     public void setInitialSync(boolean isInitialSync) {
100       this.isInitialSync = isInitialSync;
101     }
102
103     /**
104      * Instantiates a new sync task.
105      *
106      * @param initialSync the initial sync
107      */
108     public SyncTask(boolean initialSync) {
109       this.isInitialSync = initialSync;
110     }
111
112     /*
113      * (non-Javadoc)
114      * 
115      * @see java.lang.Runnable#run()
116      */
117     @Override
118     public void run() {
119       long opStartTime = System.currentTimeMillis();
120       MDC.setContextMap(contextMap);
121
122       LOG.info(AaiUiMsgs.SEARCH_ENGINE_SYNC_STARTED, sdf.format(opStartTime)
123           .replaceAll(SynchronizerConstants.TIME_STD, SynchronizerConstants.TIME_CONFIG_STD));
124
125       try {
126
127         if (syncController == null) {
128           LOG.error(AaiUiMsgs.SYNC_SKIPPED_SYNCCONTROLLER_NOT_INITIALIZED);
129           return;
130         }
131
132         int taskFrequencyInDays = SynchronizerConfiguration.getConfig().getSyncTaskFrequencyInDay();
133
134         /*
135          * Do nothing if the initial start-up sync hasn't finished yet, but the regular sync
136          * scheduler fired up a regular sync.
137          */
138         if (!initialSyncRunning) {
139           if (isInitialSync) {
140             initialSyncRunning = true;
141           } else {
142             // update 'timeNextSync' for periodic sync
143             timeNextSync.getAndAdd(taskFrequencyInDays * SynchronizerConstants.MILLISEC_IN_A_DAY);
144
145           }
146
147           LOG.info(AaiUiMsgs.INFO_GENERIC, "SyncTask, starting syncrhonization");
148
149           syncController.performAction(SyncActions.SYNCHRONIZE);
150
151           while (syncController.getState() == SynchronizerState.PERFORMING_SYNCHRONIZATION) {
152             Thread.sleep(1000);
153           }
154
155         } else {
156           LOG.info(AaiUiMsgs.SKIP_PERIODIC_SYNC_AS_SYNC_DIDNT_FINISH, sdf.format(opStartTime)
157               .replaceAll(SynchronizerConstants.TIME_STD, SynchronizerConstants.TIME_CONFIG_STD));
158
159           return;
160         }
161
162         long opEndTime = System.currentTimeMillis();
163
164         if (isInitialSync) {
165           /*
166            * Handle corner case when start-up sync operation overlapped with a scheduled
167            * sync-start-time. Note that the scheduled sync does nothing if 'initialSyncRunning' is
168            * TRUE. So the actual next-sync is one more sync-cycle away
169            */
170           long knownNextSyncTime = timeNextSync.get();
171           if (knownNextSyncTime != SynchronizerConstants.DELAY_NO_PERIODIC_SYNC_IN_MS
172               && opEndTime > knownNextSyncTime) {
173             timeNextSync.compareAndSet(knownNextSyncTime,
174                 knownNextSyncTime + taskFrequencyInDays * SynchronizerConstants.MILLISEC_IN_A_DAY);
175             initialSyncRunning = false;
176           }
177         }
178
179         String durationMessage =
180             String.format(syncController.getControllerName() + " synchronization took '%d' ms.",
181                 (opEndTime - opStartTime));
182
183         LOG.info(AaiUiMsgs.SYNC_DURATION, durationMessage);
184
185         // Provide log about the time for next synchronization
186         if (syncConfig.isConfigOkForPeriodicSync()
187             && timeNextSync.get() != SynchronizerConstants.DELAY_NO_PERIODIC_SYNC_IN_MS) {
188           TimeZone tz = TimeZone.getTimeZone(syncConfig.getSyncTaskStartTimeTimeZone());
189           sdf.setTimeZone(tz);
190           if (opEndTime - opStartTime > taskFrequencyInDays
191               * SynchronizerConstants.MILLISEC_IN_A_DAY) {
192             String durationWasLongerMessage = String.format(
193                 syncController.getControllerName()
194                     + " synchronization took '%d' ms which is larger than"
195                     + " synchronization interval of '%d' ms.",
196                 (opEndTime - opStartTime),
197                 taskFrequencyInDays * SynchronizerConstants.MILLISEC_IN_A_DAY);
198
199             LOG.info(AaiUiMsgs.SYNC_DURATION, durationWasLongerMessage);
200           }
201
202           LOG.info(AaiUiMsgs.SYNC_TO_BEGIN, syncController.getControllerName(),
203               sdf.format(timeNextSync).replaceAll(SynchronizerConstants.TIME_STD,
204                   SynchronizerConstants.TIME_CONFIG_STD));
205         }
206
207       } catch (Exception exc) {
208         String message = "Caught an exception while attempt to synchronize elastic search "
209             + "with an error cause = " + ErrorUtil.extractStackTraceElements(5, exc);
210         LOG.error(AaiUiMsgs.ERROR_GENERIC, message);
211       }
212
213     }
214
215   }
216
217
218   /**
219    * Gets the first sync time.
220    *
221    * @param calendar the calendar
222    * @param timeNow the time now
223    * @param taskFreqInDay the task freq in day
224    * @return the first sync time
225    */
226   public long getFirstSyncTime(Calendar calendar, long timeNow, int taskFreqInDay) {
227     if (taskFreqInDay == SynchronizerConstants.DELAY_NO_PERIODIC_SYNC_IN_MS) {
228       return SynchronizerConstants.DELAY_NO_PERIODIC_SYNC_IN_MS;
229     } else if (timeNow > calendar.getTimeInMillis()) {
230       calendar.add(Calendar.DAY_OF_MONTH, taskFreqInDay);
231     }
232     return calendar.getTimeInMillis();
233   }
234
235   /**
236    * Boot strap and configure the moving pieces of the Sync Controller.
237    */
238
239   private void initializeSyncController() {
240
241     try {
242
243       /*
244        * TODO: it would be nice to have XML IoC / dependency injection kind of thing for these
245        * pieces maybe Spring?
246        */
247
248       /*
249        * Sync Controller itself
250        */
251
252       syncController = new SyncController("entitySyncController");
253
254       /*
255        * Create common elements
256        */
257
258       ActiveInventoryAdapter aaiAdapter = new ActiveInventoryAdapter(new RestClientBuilder());
259       ActiveInventoryRestConfig aaiRestConfig =
260           ActiveInventoryConfig.getConfig().getAaiRestConfig();
261
262
263       EntityCache cache = null;
264
265       if (aaiRestConfig.isCacheEnabled()) {
266         cache = new PersistentEntityCache(aaiRestConfig.getStorageFolderOverride(),
267             aaiRestConfig.getNumCacheWorkers());
268       } else {
269         cache = new InMemoryEntityCache();
270       }
271
272       RestClientBuilder clientBuilder = new RestClientBuilder();
273
274       aaiAdapter.setCacheEnabled(true);
275       aaiAdapter.setEntityCache(cache);
276
277       clientBuilder.setUseHttps(false);
278
279       RestfulDataAccessor nonCachingRestProvider = new RestfulDataAccessor(clientBuilder);
280
281       ElasticSearchConfig esConfig = ElasticSearchConfig.getConfig();
282       ElasticSearchAdapter esAdapter = new ElasticSearchAdapter(nonCachingRestProvider, esConfig);
283
284       /*
285        * Register Index Validators
286        */
287
288       IndexIntegrityValidator entitySearchIndexValidator =
289           new IndexIntegrityValidator(nonCachingRestProvider, esConfig.getIndexName(),
290               esConfig.getType(), esConfig.getIpAddress(), esConfig.getHttpPort(),
291               esConfig.buildElasticSearchTableConfig());
292
293       syncController.registerIndexValidator(entitySearchIndexValidator);
294
295       // TODO: Insert IndexValidator for TopographicalEntityIndex
296       // we should have one, but one isn't 100% required as none of the fields are analyzed
297
298       /*
299        * Register Synchronizers
300        */
301
302       SearchableEntitySynchronizer ses = new SearchableEntitySynchronizer(esConfig.getIndexName());
303       ses.setAaiDataProvider(aaiAdapter);
304       ses.setEsDataProvider(esAdapter);
305       syncController.registerEntitySynchronizer(ses);
306
307       CrossEntityReferenceSynchronizer cers = new CrossEntityReferenceSynchronizer(
308           esConfig.getIndexName(), ActiveInventoryConfig.getConfig());
309       cers.setAaiDataProvider(aaiAdapter);
310       cers.setEsDataProvider(esAdapter);
311       syncController.registerEntitySynchronizer(cers);
312
313       if (syncConfig.isAutosuggestSynchronizationEnabled()) {
314         initAutoSuggestionSynchronizer(esConfig, aaiAdapter, esAdapter, nonCachingRestProvider);
315         initAggregationSynchronizer(esConfig, aaiAdapter, esAdapter, nonCachingRestProvider);
316       }
317
318       /*
319        * Register Cleaners
320        */
321
322       IndexCleaner searchableIndexCleaner = new ElasticSearchIndexCleaner(nonCachingRestProvider,
323           esConfig.getIndexName(), esConfig.getType(), esConfig.getIpAddress(),
324           esConfig.getHttpPort(), syncConfig.getScrollContextTimeToLiveInMinutes(),
325           syncConfig.getNumScrollContextItemsToRetrievePerRequest());
326
327       syncController.registerIndexCleaner(searchableIndexCleaner);
328
329     } catch (Exception exc) {
330       String message = "Error: failed to sync with message = " + exc.getMessage();
331       LOG.error(AaiUiMsgs.ERROR_GENERIC, message);
332     }
333
334   }
335
336   private List<String> getAutosuggestableEntitiesFromOXM() {
337     Map<String, OxmEntityDescriptor> map = oxmModelLoader.getSuggestionSearchEntityDescriptors();
338     List<String> suggestableEntities = new ArrayList<String>();
339
340     for (String entity : map.keySet()) {
341       suggestableEntities.add(entity);
342     }
343     return suggestableEntities;
344   }
345
346   /**
347    * Initialize the AutosuggestionSynchronizer and AggregationSuggestionSynchronizer
348    * 
349    * @param esConfig
350    * @param aaiAdapter
351    * @param esAdapter
352    * @param nonCachingRestProvider
353    */
354   private void initAutoSuggestionSynchronizer(ElasticSearchConfig esConfig,
355       ActiveInventoryAdapter aaiAdapter, ElasticSearchAdapter esAdapter,
356       RestfulDataAccessor nonCachingRestProvider) {
357     LOG.info(AaiUiMsgs.INFO_GENERIC, "initAutoSuggestionSynchronizer");
358
359     // Initialize for entityautosuggestindex
360     try {
361       IndexIntegrityValidator autoSuggestionIndexValidator =
362           new IndexIntegrityValidator(nonCachingRestProvider, esConfig.getAutosuggestIndexname(),
363               esConfig.getType(), esConfig.getIpAddress(), esConfig.getHttpPort(),
364               esConfig.buildAutosuggestionTableConfig());
365
366       syncController.registerIndexValidator(autoSuggestionIndexValidator);
367
368       AutosuggestionSynchronizer suggestionSynchronizer =
369           new AutosuggestionSynchronizer(esConfig.getAutosuggestIndexname());
370       suggestionSynchronizer.setAaiDataProvider(aaiAdapter);
371       suggestionSynchronizer.setEsDataProvider(esAdapter);
372       syncController.registerEntitySynchronizer(suggestionSynchronizer);
373
374       AggregationSuggestionSynchronizer aggregationSuggestionSynchronizer =
375           new AggregationSuggestionSynchronizer(esConfig.getAutosuggestIndexname());
376       aggregationSuggestionSynchronizer.setEsDataProvider(esAdapter);
377       syncController.registerEntitySynchronizer(aggregationSuggestionSynchronizer);
378
379       IndexCleaner autosuggestIndexCleaner = new ElasticSearchIndexCleaner(nonCachingRestProvider,
380           esConfig.getAutosuggestIndexname(), esConfig.getType(), esConfig.getIpAddress(),
381           esConfig.getHttpPort(), syncConfig.getScrollContextTimeToLiveInMinutes(),
382           syncConfig.getNumScrollContextItemsToRetrievePerRequest());
383
384       syncController.registerIndexCleaner(autosuggestIndexCleaner);
385     } catch (Exception exc) {
386       String message = "Error: failed to sync with message = " + exc.getMessage();
387       LOG.error(AaiUiMsgs.ERROR_GENERIC, message);
388     }
389   }
390
391   /**
392    * Initialize the AggregationSynchronizer
393    * 
394    * @param esConfig
395    * @param aaiAdapter
396    * @param esAdapter
397    * @param nonCachingRestProvider
398    */
399   private void initAggregationSynchronizer(ElasticSearchConfig esConfig,
400       ActiveInventoryAdapter aaiAdapter, ElasticSearchAdapter esAdapter,
401       RestfulDataAccessor nonCachingRestProvider) {
402     LOG.info(AaiUiMsgs.INFO_GENERIC, "initAggregationSynchronizer");
403
404     List<String> aggregationEntities = getAutosuggestableEntitiesFromOXM();
405
406     // For each index: create an IndexValidator, a Synchronizer, and an IndexCleaner
407     for (String entity : aggregationEntities) {
408       try {
409         String indexName = TierSupportUiConstants.getAggregationIndexName(entity);
410
411         IndexIntegrityValidator aggregationIndexValidator = new IndexIntegrityValidator(
412             nonCachingRestProvider, indexName, esConfig.getType(), esConfig.getIpAddress(),
413             esConfig.getHttpPort(), esConfig.buildAggregationTableConfig());
414
415         syncController.registerIndexValidator(aggregationIndexValidator);
416
417         /*
418          * TODO: This per-entity-synchronizer approach will eventually result in AAI / ES overload
419          * because of the existing dedicated thread pools for ES + AAI operations within the
420          * synchronizer. If we had 50 types to sync then the thread pools within each Synchronizer
421          * would cause some heartburn as there would be hundreds of threads trying to talk to AAI.
422          * Given that we our running out of time, let's make sure we can get it functional and then
423          * we'll re-visit.
424          */
425         AggregationSynchronizer aggSynchronizer = new AggregationSynchronizer(entity, indexName);
426         aggSynchronizer.setAaiDataProvider(aaiAdapter);
427         aggSynchronizer.setEsDataProvider(esAdapter);
428         syncController.registerEntitySynchronizer(aggSynchronizer);
429
430         IndexCleaner entityDataIndexCleaner = new ElasticSearchIndexCleaner(nonCachingRestProvider,
431             indexName, esConfig.getType(), esConfig.getIpAddress(), esConfig.getHttpPort(),
432             syncConfig.getScrollContextTimeToLiveInMinutes(),
433             syncConfig.getNumScrollContextItemsToRetrievePerRequest());
434
435         syncController.registerIndexCleaner(entityDataIndexCleaner);
436
437       } catch (Exception exc) {
438         String message = "Error: failed to sync with message = " + exc.getMessage();
439         LOG.error(AaiUiMsgs.ERROR_GENERIC, message);
440       }
441     }
442   }
443
444   /**
445    * Instantiates a new sync helper.
446    *
447    * @param loader the loader
448    */
449   public SyncHelper(OxmModelLoader loader) {
450     try {
451       this.contextMap = MDC.getCopyOfContextMap();
452       this.syncConfig = SynchronizerConfiguration.getConfig();
453       this.esConfig = ElasticSearchConfig.getConfig();
454       this.oxmModelLoader = loader;
455
456       UncaughtExceptionHandler uncaughtExceptionHandler = new Thread.UncaughtExceptionHandler() {
457
458         @Override
459         public void uncaughtException(Thread thread, Throwable exc) {
460           LOG.error(AaiUiMsgs.ERROR_GENERIC, thread.getName() + ": " + exc);
461         }
462       };
463
464       ThreadFactory namedThreadFactory = new ThreadFactoryBuilder().setNameFormat("SyncHelper-%d")
465           .setUncaughtExceptionHandler(uncaughtExceptionHandler).build();
466
467       periodicExecutor = Executors.newScheduledThreadPool(3, namedThreadFactory);
468
469       /*
470        * We only want to initialize the synchronizer if sync has been configured to start
471        */
472       if (syncConfig.isConfigOkForStartupSync() || syncConfig.isConfigOkForPeriodicSync()) {
473         initializeSyncController();
474       }
475
476       // schedule startup synchronization
477       if (syncConfig.isConfigOkForStartupSync()) {
478
479         long taskInitialDelayInMs = syncConfig.getSyncTaskInitialDelayInMs();
480         if (taskInitialDelayInMs != SynchronizerConstants.DELAY_NO_STARTUP_SYNC_IN_MS) {
481           oneShotExecutor.schedule(new SyncTask(true), taskInitialDelayInMs, TimeUnit.MILLISECONDS);
482           LOG.info(AaiUiMsgs.INFO_GENERIC, "Search Engine startup synchronization is enabled.");
483         } else {
484           LOG.info(AaiUiMsgs.INFO_GENERIC, "Search Engine startup synchronization is disabled.");
485         }
486       }
487
488       // schedule periodic synchronization
489       if (syncConfig.isConfigOkForPeriodicSync()) {
490
491         TimeZone tz = TimeZone.getTimeZone(syncConfig.getSyncTaskStartTimeTimeZone());
492         Calendar calendar = Calendar.getInstance(tz);
493         sdf.setTimeZone(tz);
494
495         calendar.set(Calendar.HOUR_OF_DAY, syncConfig.getSyncTaskStartTimeHr());
496         calendar.set(Calendar.MINUTE, syncConfig.getSyncTaskStartTimeMin());
497         calendar.set(Calendar.SECOND, syncConfig.getSyncTaskStartTimeSec());
498
499         long timeCurrent = calendar.getTimeInMillis();
500         int taskFrequencyInDay = syncConfig.getSyncTaskFrequencyInDay();
501         timeNextSync.getAndSet(getFirstSyncTime(calendar, timeCurrent, taskFrequencyInDay));
502
503         long delayUntilFirstRegSyncInMs = 0;
504         delayUntilFirstRegSyncInMs = timeNextSync.get() - timeCurrent;
505
506         // Do all calculation in milliseconds
507         long taskFreqencyInMs = taskFrequencyInDay * SynchronizerConstants.MILLISEC_IN_A_DAY;
508
509         if (taskFreqencyInMs != SynchronizerConstants.DELAY_NO_PERIODIC_SYNC_IN_MS) {
510           periodicExecutor.scheduleAtFixedRate(new SyncTask(false), delayUntilFirstRegSyncInMs,
511               taskFreqencyInMs, TimeUnit.MILLISECONDS);
512           LOG.info(AaiUiMsgs.INFO_GENERIC, "Search Engine periodic synchronization is enabled.");
513           // case: when - startup sync is misconfigured or is disabled
514           // - give a clue to user when is the next periodic sync
515           if (!syncConfig.isConfigOkForStartupSync()
516               || syncConfig.isConfigDisabledForInitialSync()) {
517             LOG.info(AaiUiMsgs.SYNC_TO_BEGIN, syncController.getControllerName(),
518                 sdf.format(timeNextSync).replaceAll(SynchronizerConstants.TIME_STD,
519                     SynchronizerConstants.TIME_CONFIG_STD));
520           }
521         } else {
522           LOG.info(AaiUiMsgs.INFO_GENERIC, "Search Engine periodic synchronization is disabled.");
523         }
524       }
525
526     } catch (Exception exc) {
527       String message = "Caught an exception while starting up the SyncHelper. Error cause = \n"
528           + ErrorUtil.extractStackTraceElements(5, exc);
529       LOG.error(AaiUiMsgs.ERROR_GENERIC, message);
530     }
531   }
532
533
534   /**
535    * Shutdown.
536    */
537   public void shutdown() {
538
539     if (oneShotExecutor != null) {
540       oneShotExecutor.shutdown();
541     }
542
543     if (periodicExecutor != null) {
544       periodicExecutor.shutdown();
545     }
546
547     if (historicalExecutor != null) {
548       historicalExecutor.shutdown();
549     }
550
551     if (syncController != null) {
552       syncController.shutdown();
553     }
554
555     if (entityCounterHistorySummarizer != null) {
556       entityCounterHistorySummarizer.shutdown();
557     }
558
559   }
560
561   public OxmModelLoader getOxmModelLoader() {
562     return oxmModelLoader;
563   }
564
565   public void setOxmModelLoader(OxmModelLoader oxmModelLoader) {
566     this.oxmModelLoader = oxmModelLoader;
567   }
568 }